跳过导航链接
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 

A

abort() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
abort() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
abort() - 类 中的方法org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
abort() - 接口 中的方法org.apache.flink.runtime.operators.util.JoinTaskIterator
Aborts the matching process.
abortCheckpointOnBarrier(long, Throwable) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least one CancelCheckpointMarker.
abortDeclined() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
abortError(Throwable) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint due to an error.
abortExpired() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts a checkpoint because it expired (took too long).
abortSubsumed() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
absoluteTimeMillis() - 类 中的方法org.apache.flink.runtime.util.clock.Clock
 
absoluteTimeMillis() - 类 中的方法org.apache.flink.runtime.util.clock.SystemClock
 
AbstractAggregatedMetricsHeaders<P extends AbstractAggregatedMetricsParameters<?>> - org.apache.flink.runtime.rest.messages.job.metrics中的类
Based MessageHeaders class for aggregating metrics.
AbstractAggregatedMetricsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
 
AbstractAggregatedMetricsParameters<M extends MessageQueryParameter<?>> - org.apache.flink.runtime.rest.messages.job.metrics中的类
Base MessageParameters class for aggregating metrics.
AbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>> - org.apache.flink.runtime.rest.handler.job.metrics中的类
Abstract request handler for querying aggregated metrics.
AbstractAggregatingMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, AbstractAggregatedMetricsHeaders<P>, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
 
AbstractAsynchronousOperationHandlers<K extends OperationKey,R> - org.apache.flink.runtime.rest.handler.async中的类
HTTP handlers for asynchronous operations.
AbstractAsynchronousOperationHandlers() - 类 的构造器org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers
 
AbstractAsynchronousOperationHandlers.StatusHandler<T extends RestfulGateway,V,M extends MessageParameters> - org.apache.flink.runtime.rest.handler.async中的类
Handler which will be polled to retrieve the asynchronous operation's result.
AbstractAsynchronousOperationHandlers.TriggerHandler<T extends RestfulGateway,B extends RequestBody,M extends MessageParameters> - org.apache.flink.runtime.rest.handler.async中的类
Handler which is responsible for triggering an asynchronous operation.
AbstractBlobCache - org.apache.flink.runtime.blob中的类
Abstract base class for permanent and transient BLOB files.
AbstractBlobCache(Configuration, BlobView, Logger, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.blob.AbstractBlobCache
 
AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
AbstractCachedBuildSideJoinDriver(int, int) - 类 的构造器org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> - org.apache.flink.runtime.rest.handler.job.checkpoints中的类
Base class for checkpoint related REST handler.
AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor, CheckpointStatsCache) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
 
AbstractCheckpointMessage - org.apache.flink.runtime.messages.checkpoint中的类
The base class of all checkpoint messages.
AbstractCheckpointMessage(JobID, ExecutionAttemptID, long) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
AbstractCheckpointStats - org.apache.flink.runtime.checkpoint中的类
Base class for checkpoint statistics.
AbstractDispatcherResourceManagerComponentFactory<T extends Dispatcher,U extends RestfulGateway> - org.apache.flink.runtime.entrypoint.component中的类
Abstract class which implements the creation of the DispatcherResourceManagerComponent components.
AbstractDispatcherResourceManagerComponentFactory(DispatcherFactory<T>, ResourceManagerFactory<?>, RestEndpointFactory<U>) - 类 的构造器org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
 
AbstractEvent - org.apache.flink.runtime.event中的类
This type of event can be used to exchange notification messages between different TaskManager objects at runtime using the communication channels.
AbstractEvent() - 类 的构造器org.apache.flink.runtime.event.AbstractEvent
 
AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> - org.apache.flink.runtime.rest.handler.job中的类
Base class for all AccessExecutionGraph based REST handlers.
AbstractExecutionGraphHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
 
AbstractFileIOChannel - org.apache.flink.runtime.io.disk.iomanager中的类
 
AbstractFileIOChannel(FileIOChannel.ID, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
Creates a new channel to the path indicated by the given ID.
AbstractFileStateBackend - org.apache.flink.runtime.state.filesystem中的类
A base class for all state backends that store their metadata (and data) in files.
AbstractFileStateBackend(URI, URI) - 类 的构造器org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Creates a backend with the given optional checkpoint- and savepoint base directories.
AbstractFileStateBackend(Path, Path) - 类 的构造器org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Creates a backend with the given optional checkpoint- and savepoint base directories.
AbstractFileStateBackend(Path, Path, Configuration) - 类 的构造器org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Creates a new backend using the given checkpoint-/savepoint directories, or the values defined in the given configuration.
AbstractFsCheckpointStorage - org.apache.flink.runtime.state.filesystem中的类
An implementation of durable checkpoint storage to file systems.
AbstractFsCheckpointStorage(JobID, Path) - 类 的构造器org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates a new checkpoint storage.
AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters> - org.apache.flink.runtime.rest.handler中的类
Super class for netty-based handlers that work with RequestBody.
AbstractHandler(GatewayRetriever<? extends T>, Time, Map<String, String>, UntypedResponseMessageHeaders<R, M>) - 类 的构造器org.apache.flink.runtime.rest.handler.AbstractHandler
 
AbstractHashTableProber<PT,BT> - org.apache.flink.runtime.operators.hash中的类
 
AbstractHashTableProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - 类 的构造器org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的类
Abstract base class for heap (object array) based implementations of priority queues, with support for fast deletes via HeapPriorityQueueElement.
AbstractHeapPriorityQueue(int) - 类 的构造器org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
AbstractHeapState<K,N,SV> - org.apache.flink.runtime.state.heap中的类
Base class for partitioned State implementations that are backed by a regular heap hash map.
AbstractInvokable - org.apache.flink.runtime.jobgraph.tasks中的类
This is the abstract base class for every task that can be executed by a TaskManager.
AbstractInvokable(Environment) - 类 的构造器org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Create an Invokable task and set its environment.
AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT> - org.apache.flink.runtime.iterative.task中的类
The abstract base class for all tasks able to participate in an iteration.
AbstractIterativeTask(Environment) - 类 的构造器org.apache.flink.runtime.iterative.task.AbstractIterativeTask
Create an Invokable task and set its environment.
AbstractJobVertexHandler<R extends ResponseBody,M extends JobVertexMessageParameters> - org.apache.flink.runtime.rest.handler.job中的类
Base class for request handlers whose response depends on a specific job vertex (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).
AbstractJobVertexHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
Instantiates a new Abstract job vertex handler.
AbstractKeyedStateBackend<K> - org.apache.flink.runtime.state中的类
Base implementation of KeyedStateBackend.
AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, CloseableRegistry) - 类 的构造器org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
AbstractKeyedStateBackend(TaskKvStateRegistry, StateSerializerProvider<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, CloseableRegistry, StreamCompressionDecorator) - 类 的构造器org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
AbstractKeyedStateBackendBuilder<K> - org.apache.flink.runtime.state中的类
An abstract base implementation of the StateBackendBuilder interface.
AbstractKeyedStateBackendBuilder(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, Collection<KeyedStateHandle>, StreamCompressionDecorator, CloseableRegistry) - 类 的构造器org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
AbstractMergeInnerJoinIterator<T1,T2,O> - org.apache.flink.runtime.operators.sort中的类
An implementation of the JoinTaskIterator that realizes the joining through a sort-merge join strategy.
AbstractMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
 
AbstractMergeIterator<T1,T2,O> - org.apache.flink.runtime.operators.sort中的类
 
AbstractMergeIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
AbstractMergeOuterJoinIterator<T1,T2,O> - org.apache.flink.runtime.operators.sort中的类
An implementation of the JoinTaskIterator that realizes the outer join through a sort-merge join strategy.
AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
 
AbstractMetricGroup<A extends AbstractMetricGroup<?>> - org.apache.flink.runtime.metrics.groups中的类
Abstract MetricGroup that contains key functionality for adding metrics and groups.
AbstractMetricGroup(MetricRegistry, String[], A) - 类 的构造器org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
AbstractMetricGroup.ChildType - org.apache.flink.runtime.metrics.groups中的枚举
Enum for indicating which child group should be created.
AbstractMetricsHandler<M extends MessageParameters> - org.apache.flink.runtime.rest.handler.job.metrics中的类
Request handler that returns for a given task a list of all available metrics or the values for a set of metrics.
AbstractMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, MetricCollectionResponseBody, M>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
 
AbstractMetricsHeaders<M extends MessageParameters> - org.apache.flink.runtime.rest.messages.job.metrics中的类
AbstractMetricsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
AbstractMutableHashTable<T> - org.apache.flink.runtime.operators.hash中的类
 
AbstractMutableHashTable(TypeSerializer<T>, TypeComparator<T>) - 类 的构造器org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
AbstractNonHaServices - org.apache.flink.runtime.highavailability.nonha中的类
Abstract base class for non high-availability services.
AbstractNonHaServices() - 类 的构造器org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
AbstractOuterJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
The abstract outer join driver implements the logic of an outer join operator at runtime.
AbstractOuterJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
AbstractPagedInputView - org.apache.flink.runtime.memory中的类
The base class for all input views that are backed by multiple memory pages.
AbstractPagedInputView(MemorySegment, int, int) - 类 的构造器org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that starts with the given segment.
AbstractPagedInputView(int) - 类 的构造器org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that is initially not bound to a memory segment.
AbstractPagedOutputView - org.apache.flink.runtime.memory中的类
The base class for all output views that are backed by multiple memory pages.
AbstractPagedOutputView(MemorySegment, int, int) - 类 的构造器org.apache.flink.runtime.memory.AbstractPagedOutputView
Creates a new output view that writes initially to the given initial segment.
AbstractPagedOutputView(int, int) - 类 的构造器org.apache.flink.runtime.memory.AbstractPagedOutputView
 
AbstractReader - org.apache.flink.runtime.io.network.api.reader中的类
A basic reader implementation, which wraps an input gate and handles events.
AbstractReader(InputGate) - 类 的构造器org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - org.apache.flink.runtime.rest.handler中的类
Super class for netty-based handlers that work with RequestBodys and ResponseBodys.
AbstractRestHandler(GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<R, P, M>) - 类 的构造器org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
AbstractSnapshotStrategy<T extends StateObject> - org.apache.flink.runtime.state中的类
Abstract base class for implementing SnapshotStrategy, that gives a consistent logging across state backends.
AbstractSnapshotStrategy(String) - 类 的构造器org.apache.flink.runtime.state.AbstractSnapshotStrategy
 
AbstractStateBackend - org.apache.flink.runtime.state中的类
An abstract base implementation of the StateBackend interface.
AbstractStateBackend() - 类 的构造器org.apache.flink.runtime.state.AbstractStateBackend
 
AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters> - org.apache.flink.runtime.rest.handler.job中的类
Base class for request handlers whose response depends on a specific attempt (defined via the "SubtaskAttemptPathParameter.KEY" of a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).
AbstractSubtaskAttemptHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
Instantiates a new Abstract job vertex handler.
AbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskMessageParameters> - org.apache.flink.runtime.rest.handler.job中的类
Base class for request handlers whose response depends on a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).
AbstractSubtaskHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
Instantiates a new Abstract job vertex handler.
AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters> - org.apache.flink.runtime.rest.handler.taskmanager中的类
Base class for serving files from the TaskExecutor.
AbstractTaskManagerFileHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
acceptsFileUploads() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
acceptsFileUploads() - 接口 中的方法org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
Returns whether this header allows file uploads.
AccessExecution - org.apache.flink.runtime.executiongraph中的接口
Common interface for the runtime Execution and {@link ArchivedExecution}.
AccessExecutionGraph - org.apache.flink.runtime.executiongraph中的接口
Common interface for the runtime ExecutionGraph and ArchivedExecutionGraph.
AccessExecutionJobVertex - org.apache.flink.runtime.executiongraph中的接口
Common interface for the runtime ExecutionJobVertex and ArchivedExecutionJobVertex.
AccessExecutionVertex - org.apache.flink.runtime.executiongraph中的接口
Common interface for the runtime ExecutionVertex and ArchivedExecutionVertex.
accumulatorMap - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The accumulator map used in the RuntimeContext.
AccumulatorRegistry - org.apache.flink.runtime.accumulators中的类
Main accumulator registry which encapsulates user-defined accumulators.
AccumulatorRegistry(JobID, ExecutionAttemptID) - 类 的构造器org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
AccumulatorReport - org.apache.flink.runtime.taskexecutor中的类
A report about the current values of all accumulators of the TaskExecutor for a given job.
AccumulatorReport(List<AccumulatorSnapshot>) - 类 的构造器org.apache.flink.runtime.taskexecutor.AccumulatorReport
 
accumulatorResults(Map<String, SerializedValue<OptionalFailure<Object>>>) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
AccumulatorsIncludeSerializedValueQueryParameter - org.apache.flink.runtime.rest.messages中的类
Query parameter for job's accumulator handler JobAccumulatorsHandler.
AccumulatorsIncludeSerializedValueQueryParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
AccumulatorSnapshot - org.apache.flink.runtime.accumulators中的类
This class encapsulates a map of accumulators for a single task.
AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<String, Accumulator<?, ?>>) - 类 的构造器org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
Acknowledge - org.apache.flink.runtime.messages中的类
A generic acknowledgement message.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
acknowledgeCheckpoint(long, CheckpointMetrics) - 接口 中的方法org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all steps it needed to to for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all required steps for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
AcknowledgeCheckpoint - org.apache.flink.runtime.messages.checkpoint中的类
This message is sent from the TaskExecutor to the JobMaster to signal that the checkpoint of an individual task is completed.
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.taskmanager.CheckpointResponder
Acknowledges the given checkpoint.
acknowledgeCheckpoint(long, CheckpointMetrics) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeTask(ExecutionAttemptID, TaskStateSnapshot, CheckpointMetrics) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Acknowledges the task with the given execution attempt id and the given subtask state.
actor() - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Returns the underlying actor with which is communicated
actor() - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Returns ActorRef of the target actor
ActorGateway - org.apache.flink.runtime.instance中的接口
Interface to abstract the communication with an actor.
ActorGatewayCheckpointResponder - org.apache.flink.runtime.taskmanager中的类
Implementation using ActorGateway to forward the messages.
ActorGatewayCheckpointResponder(ActorGateway) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
ActorGatewayGlobalAggregateManager - org.apache.flink.runtime.taskmanager中的类
 
ActorGatewayGlobalAggregateManager() - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayGlobalAggregateManager
 
ActorGatewayKvStateLocationOracle - org.apache.flink.runtime.taskmanager中的类
ActorGatewayKvStateLocationOracle(ActorGateway, Time) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
 
ActorGatewayKvStateRegistryListener - org.apache.flink.runtime.taskmanager中的类
This implementation uses ActorGateway to forward key-value state notifications to the job manager.
ActorGatewayKvStateRegistryListener(ActorGateway, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
ActorGatewayPartitionProducerStateChecker - org.apache.flink.runtime.taskmanager中的类
This implementation uses ActorGateway to trigger the partition state check at the job manager.
ActorGatewayPartitionProducerStateChecker(ActorGateway, FiniteDuration) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
ActorGatewayResultPartitionConsumableNotifier - org.apache.flink.runtime.taskmanager中的类
This implementation uses ActorGateway to notify the job manager about consumable partitions.
ActorGatewayResultPartitionConsumableNotifier(ExecutionContext, ActorGateway, FiniteDuration) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
ActorGatewayTaskManagerActions - org.apache.flink.runtime.taskmanager中的类
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskManagerActions(ActorGateway) - 类 的构造器org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
ActorSystemScheduledExecutorAdapter - org.apache.flink.runtime.concurrent.akka中的类
Adapter to use a ActorSystem as a ScheduledExecutor.
ActorSystemScheduledExecutorAdapter(ActorSystem) - 类 的构造器org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
ActorTaskManagerGateway - org.apache.flink.runtime.jobmanager.slots中的类
Implementation of the TaskManagerGateway for ActorGateway.
ActorTaskManagerGateway(ActorGateway) - 类 的构造器org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
ActorUtils - org.apache.flink.runtime.akka中的类
Utility functions for the interaction with Akka Actor.
actualModVersion() - 异常错误 中的方法org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
add(T) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
add(BufferConsumer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Adds the given buffer.
add(MetricDump) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
add(T) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
add(T) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
Adds the element to the queue.
add(T) - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
add(T) - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Adds the given element to the set, if it is not already contained.
add(S) - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
add(Task) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Add the given task to the task slot.
add(T) - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
add(int) - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
add(long) - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
addAll(Collection<? extends T>) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
addAll(Collection<? extends T>) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
addAll(Collection<? extends T>) - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
addAll(List<T>) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalListState
Updates the operator state accessible by AppendingState.get() by adding the given values to existing list of values.
addAll(Collection<? extends T>) - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Adds all the given elements to the set.
addAll(List<S>) - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
addAndLock(String, T) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle, stores it in ZooKeeper and locks it.
addAny(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addAppConfigurationEntry(String, AppConfigurationEntry...) - 类 中的方法org.apache.flink.runtime.security.DynamicConfiguration
Add entries for the given application name.
addBroadcastInputToGroup(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addBufferConsumer(BufferConsumer, int) - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Adds the bufferConsumer to the subpartition with the given index.
addBufferConsumer(BufferConsumer, int) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
addBufferListener(BufferListener) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Adds a buffer availability listener to the buffer provider.
addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addCheckpoint(CompletedCheckpoint) - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Adds a CompletedCheckpoint instance to the list of completed checkpoints.
addCheckpoint(CompletedCheckpoint) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
addCheckpoint(CompletedCheckpoint) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
addConnect(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addConsumer(JobEdge) - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
addCredit(int) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
The credits from consumer are added in incremental way.
addDelete(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addGet(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addGroup(int) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String, String) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String, String) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
 
addGroup(int) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroup(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroup(String, String) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addHash(int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter
 
addHead(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addInputChannel(RemoteInputChannel) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkClientHandler
 
addInputToGroup(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addInstanceListener(InstanceListener) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
addInternal(T) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
Implements how to add an element to the queue.
addInternal(T) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueue
 
addIOMetrics(AccessExecution, MetricFetcher, String, String) - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
Adds the IO metrics for the given attempt to this object.
addIterationAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addIterationAggregators(Collection<AggregatorWithName<?>>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addJar(Path) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Adds the path of a JAR file required to run the job on a task manager.
addJob(JobGraph) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
addJob(JobGraph) - 类 中的方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup
 
addJob(JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Add a job to be monitored to retrieve the job leader id.
addJob(JobID, String) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Add the given job to be monitored.
addMasterHook(MasterTriggerRestoreHook<?>) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Adds the given master hook to the checkpoint coordinator.
addMasterState(MasterState) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Adds a master state (state generated on the checkpoint coordinator) to the pending checkpoint.
addMetric(String, Metric) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Adds the given metric to the group and registers it at the registry, if the group is not yet closed, and if no metric with the same name has been registered before.
addNameSpace(Set<String>) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
addOptions(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addOutputShipStrategy(ShipStrategyType) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
addPatch(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addPost(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addPut(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addRecord(T) - 类 中的方法org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
addRequest(R) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
 
address() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the network address the instance's task manager binds its sockets to.
addressString() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the IP address where the TaskManager operates.
addRoute(HttpMethod, String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Add route.
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, JobVertexID) - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, CoLocationConstraint) - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - 类 中的方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
 
addTask(Task) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Add the given task to the slot identified by the task's allocation id.
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - 类 中的方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup
 
addToMessageDigest(MessageDigest) - 类 中的方法org.apache.flink.runtime.blob.BlobKey
Adds the BLOB key to the given MessageDigest.
addTrace(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
addUserArtifact(String, DistributedCache.DistributedCacheEntry) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Adds the path of a custom file required to run the job on a task manager.
addUserJarBlobKey(PermanentBlobKey) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Adds the BLOB referenced by the key to the JobGraph's dependencies.
addVertex(JobVertex) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Adds a new task vertex to the job graph if it is not already included.
addVertex(JobVertex) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
addVertexToGroup(JobVertexID) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
adjustModifiedElement(T) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueue
 
adjustTop() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Should be called when the Object at top changes values.
advance() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Advances the view to the next memory segment.
advance() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
Moves the output view to the next page.
AggregatedJobMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
Headers for aggregating job metrics.
AggregatedJobMetricsParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
Parameters for aggregating job metrics.
AggregatedJobMetricsParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
 
AggregatedMetric - org.apache.flink.runtime.rest.messages.job.metrics中的类
Response type for aggregated metrics.
AggregatedMetric(String, Double, Double, Double, Double) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
AggregatedMetric(String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
AggregatedMetricsResponseBody - org.apache.flink.runtime.rest.messages.job.metrics中的类
Response type for a collection of aggregated metrics.
AggregatedMetricsResponseBody(Collection<AggregatedMetric>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
 
AggregatedMetricsResponseBody.Deserializer - org.apache.flink.runtime.rest.messages.job.metrics中的类
JSON deserializer for AggregatedMetricsResponseBody.
AggregatedMetricsResponseBody.Serializer - org.apache.flink.runtime.rest.messages.job.metrics中的类
JSON serializer for AggregatedMetricsResponseBody.
AggregatedSubtaskMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
Headers for aggregating subtask metrics.
AggregatedSubtaskMetricsParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
Parameters for aggregating subtask metrics.
AggregatedSubtaskMetricsParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
 
AggregatedTaskManagerMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
Headers for aggregating task manager metrics.
AggregateTaskManagerMetricsParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
Parameters for aggregating task manager metrics.
AggregateTaskManagerMetricsParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
 
aggregateUserAccumulators() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Merges all accumulator results from the tasks previously executed in the Executions.
AggregatingJobsMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Request handler that returns, aggregated across jobs, a list of all available metrics or the values for a set of metrics.
AggregatingJobsMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.AggregatingJobsMetricsHandler
 
AggregatingSubtasksMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Request handler that returns, aggregated across subtasks, a list of all available metrics or the values for a set of metrics.
AggregatingSubtasksMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.AggregatingSubtasksMetricsHandler
 
AggregatingTaskManagersMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Request handler that returns, aggregated across task managers, a list of all available metrics or the values for a set of metrics.
AggregatingTaskManagersMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.AggregatingTaskManagersMetricsHandler
 
AGGREGATOR_NAME - 类 中的静态变量org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
AkkaActorGateway - org.apache.flink.runtime.instance中的类
Concrete ActorGateway implementation which uses Akka to communicate with remote actors.
AkkaActorGateway(ActorRef, UUID) - 类 的构造器org.apache.flink.runtime.instance.AkkaActorGateway
 
AkkaHandshakeException - org.apache.flink.runtime.rpc.akka.exceptions中的异常错误
Exception which is thrown if the handshake fails.
AkkaHandshakeException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaHandshakeException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaHandshakeException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaQueryServiceGateway - org.apache.flink.runtime.webmonitor.retriever.impl中的类
MetricQueryServiceGateway implementation for Akka based MetricQueryService.
AkkaQueryServiceGateway(ActorRef) - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
AkkaQueryServiceRetriever - org.apache.flink.runtime.webmonitor.retriever.impl中的类
MetricQueryServiceRetriever implementation for Akka based MetricQueryService.
AkkaQueryServiceRetriever(ActorSystem, Time) - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
 
AkkaRpcException - org.apache.flink.runtime.rpc.akka.exceptions中的异常错误
Base class for Akka RPC related exceptions.
AkkaRpcException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcInvalidStateException - org.apache.flink.runtime.rpc.akka.exceptions中的异常错误
Exception which indicates an invalid state.
AkkaRpcInvalidStateException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcInvalidStateException
 
AkkaRpcInvalidStateException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcInvalidStateException
 
AkkaRpcInvalidStateException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcInvalidStateException
 
AkkaRpcService - org.apache.flink.runtime.rpc.akka中的类
Akka based RpcService implementation.
AkkaRpcService(ActorSystem, AkkaRpcServiceConfiguration) - 类 的构造器org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
AkkaRpcServiceConfiguration - org.apache.flink.runtime.rpc.akka中的类
Configuration for the AkkaRpcService.
AkkaRpcServiceConfiguration(Configuration, Time, long) - 类 的构造器org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
AkkaRpcServiceUtils - org.apache.flink.runtime.rpc.akka中的类
These RPC utilities contain helper methods around RPC use, such as starting an RPC service, or constructing RPC addresses.
AkkaRpcServiceUtils.AkkaProtocol - org.apache.flink.runtime.rpc.akka中的枚举
Whether to use TCP or encrypted TCP for Akka.
AkkaUnknownMessageException - org.apache.flink.runtime.rpc.akka.exceptions中的异常错误
Exception which indicates that the AkkaRpcActor has received an unknown message type.
AkkaUnknownMessageException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AlignmentLimitExceededException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because too many bytes were buffered in the alignment phase.
AlignmentLimitExceededException(long) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.AlignmentLimitExceededException
 
all() - 类 中的静态方法org.apache.flink.runtime.types.FlinkChillPackageRegistrar
 
allAllowedMethods() - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Returns all methods that this router handles.
AllGroupCombineDriver<IN,OUT> - org.apache.flink.runtime.operators中的类
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
AllGroupCombineDriver() - 类 的构造器org.apache.flink.runtime.operators.AllGroupCombineDriver
 
AllGroupReduceDriver<IT,OT> - org.apache.flink.runtime.operators中的类
GroupReduceDriver task which is executed by a Task Manager.
AllGroupReduceDriver() - 类 的构造器org.apache.flink.runtime.operators.AllGroupReduceDriver
 
alloc() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
allocate(JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Allocate the task slot for the given job and allocation id.
allocateAndAssignSlotForExecution(SlotProvider, boolean, LocationPreferenceConstraint, Set<AllocationID>, Time) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Allocates and assigns a slot obtained from the slot provider to the execution.
allocateAvailableSlot(SlotRequestId, AllocationID) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Allocates the available slot with the given allocation id under the given request id.
allocateAvailableSlot(SlotRequestId, AllocationID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
AllocatedSlotActions - org.apache.flink.runtime.jobmaster.slotpool中的接口
Interface for components which have to perform actions on allocated slots.
AllocatedSlotInfo - org.apache.flink.runtime.jobmaster中的类
Information about an allocated slot which is owned by a JobMaster.
AllocatedSlotInfo(int, AllocationID) - 类 的构造器org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
 
AllocatedSlotReport - org.apache.flink.runtime.jobmaster中的类
The report of currently allocated slots from a given TaskExecutor by a JobMaster.
AllocatedSlotReport(JobID, Collection<AllocatedSlotInfo>) - 类 的构造器org.apache.flink.runtime.jobmaster.AllocatedSlotReport
 
allocatePages(Object, int) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocatePages(Object, List<MemorySegment>, int) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocateResource(ResourceProfile) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Allocates a resource according to the resource profile.
allocateResource(ResourceProfile) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Requests to allocate a resource with the given ResourceProfile.
allocateResourcesForAll(SlotProvider, boolean, LocationPreferenceConstraint, Set<AllocationID>, Time) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
allocateSegments(int) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
attempts to allocate specified number of segments and should only be used by compaction partition fails silently if not enough segments are available since next compaction could still succeed
allocateSharedSlot(SlotSharingGroupAssignment) - 类 中的方法org.apache.flink.runtime.instance.Instance
Allocates a shared slot on this TaskManager instance.
allocateSimpleSlot() - 类 中的方法org.apache.flink.runtime.instance.Instance
Allocates a simple slot on this TaskManager instance.
allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Allocating slot with specific requirement.
allocateSlot(ScheduledUnit, boolean, SlotProfile, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Allocating slot with specific requirement.
allocateSlot(int, JobID, AllocationID, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Allocate the slot with the given index for the given job and allocation id.
allocationBaseDirectory(long) - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state allocation base directory for given checkpoint id w.r.t. our rotation over all available allocation base directories.
allocationBaseDirectory(long) - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
allocationBaseDirsCount() - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the total number of allocation base directories.
allocationBaseDirsCount() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
allocationFuture - 类 中的变量org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
AllocationID - org.apache.flink.runtime.clusterframework.types中的类
Unique identifier for a physical slot allocated by a JobManager via the ResourceManager from a TaskManager.
AllocationID() - 类 的构造器org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new random AllocationID.
AllocationID(long, long) - 类 的构造器org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new AllocationID with the given parts.
allowedMethods(String) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Returns allowed methods for a specific URI.
allowLazyDeployment() - 枚举 中的方法org.apache.flink.runtime.jobgraph.ScheduleMode
Returns whether we are allowed to deploy consumers lazily.
allowNonRestoredState() - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether non restored state is allowed if the savepoint contains state that cannot be mapped back to the job.
AllReduceDriver<T> - org.apache.flink.runtime.operators中的类
Reduce task which is executed by a Task Manager.
AllReduceDriver() - 类 的构造器org.apache.flink.runtime.operators.AllReduceDriver
 
AllWorkersDoneEvent - org.apache.flink.runtime.iterative.event中的类
Event sent by the IterationSynchronizationSinkTask to each IterationHead signaling to start a new superstep.
AllWorkersDoneEvent() - 类 的构造器org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
 
AllWorkersDoneEvent(Map<String, Aggregator<?>>) - 类 的构造器org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
 
AnnotationVisitorImpl(int) - 类 的构造器org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
ANY - 类 中的静态变量org.apache.flink.runtime.clusterframework.types.ResourceProfile
ResourceProfile which matches any other ResourceProfile.
append(ByteBuffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
Append as many data as possible from source.
appendAndCommit(ByteBuffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
Same as BufferBuilder.append(ByteBuffer) but additionally BufferBuilder.commit() the appending.
appendRecord(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
Inserts the given object into the current buffer.
ApplicationStatus - org.apache.flink.runtime.clusterframework中的枚举
The status of an application.
applicationStatus(ApplicationStatus) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
apply(S, T) - 接口 中的方法org.apache.flink.runtime.state.StateTransformationFunction
Binary function that applies a given value to the given old state to compute the new state.
applyRepartitioner(OperatorID, OperatorStateRepartitioner, List<List<OperatorStateHandle>>, int, int) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
applyRepartitioner(OperatorStateRepartitioner, List<List<OperatorStateHandle>>, int, int) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Repartitions the given operator state using the given OperatorStateRepartitioner with respect to the new parallelism.
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
Applies the provided KeyedStateFunction to the state with the provided StateDescriptor of all the currently active keys.
archive() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
archive() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
archive() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
ARCHIVE_NAME - 类 中的静态变量org.apache.flink.runtime.jobmaster.JobMaster
 
ArchivedExecution - org.apache.flink.runtime.executiongraph中的类
 
ArchivedExecution(Execution) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, int, ExecutionState, String, TaskManagerLocation, AllocationID, int, long[]) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecutionGraph - org.apache.flink.runtime.executiongraph中的类
An archived execution graph represents a serializable form of the ExecutionGraph.
ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, ErrorInfo, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<OptionalFailure<Object>>>, ArchivedExecutionConfig, boolean, CheckpointCoordinatorConfiguration, CheckpointStatsSnapshot) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
ArchivedExecutionGraphStore - org.apache.flink.runtime.dispatcher中的接口
Interface for a ArchivedExecutionGraph store.
ArchivedExecutionJobVertex - org.apache.flink.runtime.executiongraph中的类
 
ArchivedExecutionJobVertex(ExecutionJobVertex) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, StringifiedAccumulatorResult[]) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionVertex - org.apache.flink.runtime.executiongraph中的类
 
ArchivedExecutionVertex(ExecutionVertex) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedExecutionVertex(int, String, ArchivedExecution, EvictingBoundedList<ArchivedExecution>) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedJson - org.apache.flink.runtime.webmonitor.history中的类
A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
ArchivedJson(String, String) - 类 的构造器org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
ArchivedJson(String, ResponseBody) - 类 的构造器org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
archiveExecutionGraph(AccessExecutionGraph) - 接口 中的方法org.apache.flink.runtime.dispatcher.HistoryServerArchivist
Archives the given AccessExecutionGraph on the history server.
archiveExecutionGraph(AccessExecutionGraph) - 枚举 中的方法org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
 
archiveJob(Path, JobID, Collection<ArchivedJson>) - 类 中的静态方法org.apache.flink.runtime.history.FsJobArchivist
Writes the given AccessExecutionGraph to the FileSystem pointed to by JobManagerOptions.ARCHIVE_DIR.
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobConfigHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobPlanHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
 
archiveJsonWithPath(AccessExecutionGraph) - 接口 中的方法org.apache.flink.runtime.webmonitor.history.JsonArchivist
Returns a Collection of ArchivedJsons containing JSON responses and their respective REST URL for a given job.
archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
areAllPartitionsReleased() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
array() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
ArrayListSerializer<T> - org.apache.flink.runtime.state中的类
 
ArrayListSerializer(TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.state.ArrayListSerializer
 
ArrayListSerializerSnapshot<T> - org.apache.flink.runtime.state中的类
Snapshot class for the ArrayListSerializer.
ArrayListSerializerSnapshot() - 类 的构造器org.apache.flink.runtime.state.ArrayListSerializerSnapshot
Constructor for read instantiation.
ArrayListSerializerSnapshot(ArrayListSerializer<T>) - 类 的构造器org.apache.flink.runtime.state.ArrayListSerializerSnapshot
Constructor for creating the snapshot for writing.
arrayOffset() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
arrayToMap(String[]) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
Artifact(Path, Path, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
artifactFileNames - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
asByteBuf() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
 
asByteBuf() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
asByteBuf() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
ask(Object, FiniteDuration) - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously and returns its response.
ask(Object, FiniteDuration) - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously and returns its response.
ask(Object, Time) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
asList() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
assertNoException(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Asserts that the given CompletableFuture is not completed exceptionally.
assertRunningInMainThread() - 接口 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor
Returns true if the method was called in the thread of this executor.
assertRunningInMainThread() - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
assertRunningInMainThread() - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutorServiceAdapter
 
assertRunningInMainThread() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
assignExclusiveSegments(NetworkBufferPool, int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Assign the exclusive buffers to all remote input channels directly for credit-based mode.
assignKeyToParallelOperator(Object, int, int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a parallel operator index.
assignPartition(int, byte) - 类 中的静态方法org.apache.flink.runtime.operators.hash.MutableHashTable
Assigns a partition to a bucket.
assignPendingSlotRequest(PendingSlotRequest) - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
assignPendingSlotRequest(PendingSlotRequest) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
assignPendingTaskManagerSlot(PendingTaskManagerSlot) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
AssignRangeIndex<IN> - org.apache.flink.runtime.operators.udf中的类
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate Tuple2 which includes range index and record itself as output.
AssignRangeIndex(TypeComparatorFactory<IN>) - 类 的构造器org.apache.flink.runtime.operators.udf.AssignRangeIndex
 
assignStates() - 类 中的方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
assignToKeyGroup(Object, int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
asVariable(String) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
Formats the given string to resemble a scope variable.
AsynchronousBlockReader - org.apache.flink.runtime.io.disk.iomanager中的类
A reader that reads data in blocks from a file channel.
AsynchronousBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, LinkedBlockingQueue<MemorySegment>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Creates a new block channel reader for the given channel.
AsynchronousBlockWriter - org.apache.flink.runtime.io.disk.iomanager中的类
 
AsynchronousBlockWriter(FileIOChannel.ID, RequestQueue<WriteRequest>, LinkedBlockingQueue<MemorySegment>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Creates a new block channel writer for the given channel.
AsynchronousBlockWriterWithCallback - org.apache.flink.runtime.io.disk.iomanager中的类
An asynchronous implementation of the BlockChannelWriterWithCallback that queues I/O requests and calls a callback once they have been handled.
AsynchronousBlockWriterWithCallback(FileIOChannel.ID, RequestQueue<WriteRequest>, RequestDoneCallback<MemorySegment>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
Creates a new asynchronous block writer for the given channel.
AsynchronousBufferFileReader - org.apache.flink.runtime.io.disk.iomanager中的类
 
AsynchronousBufferFileReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<Buffer>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
AsynchronousBufferFileSegmentReader - org.apache.flink.runtime.io.disk.iomanager中的类
 
AsynchronousBufferFileSegmentReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<FileSegment>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
AsynchronousBufferFileWriter - org.apache.flink.runtime.io.disk.iomanager中的类
 
AsynchronousBufferFileWriter(FileIOChannel.ID, RequestQueue<WriteRequest>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
AsynchronousBulkBlockReader - org.apache.flink.runtime.io.disk.iomanager中的类
 
AsynchronousBulkBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, List<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> - org.apache.flink.runtime.io.disk.iomanager中的类
A base class for readers and writers that accept read or write requests for whole blocks.
AsynchronousFileIOChannel(FileIOChannel.ID, RequestQueue<R>, RequestDoneCallback<T>, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Creates a new channel access to the path indicated by the given ID.
AsynchronousJobOperationKey - org.apache.flink.runtime.rest.handler.job中的类
A pair of JobID and TriggerId used as a key to a hash based collection.
AsynchronouslyCreatedResource<T> - org.apache.flink.runtime.rest.messages.queue中的接口
Interface for REST resources that are created asynchronously.
AsynchronousOperationInfo - org.apache.flink.runtime.rest.handler.async中的类
Basic information object for asynchronous operations.
AsynchronousOperationResult<V> - org.apache.flink.runtime.rest.handler.async中的类
Result of an asynchronous operation.
AsynchronousOperationStatusMessageHeaders<V,M extends MessageParameters> - org.apache.flink.runtime.rest.handler.async中的类
Message headers for the status polling of an asynchronous operation.
AsynchronousOperationStatusMessageHeaders() - 类 的构造器org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
 
AsynchronousOperationTriggerMessageHeaders<R extends RequestBody,M extends MessageParameters> - org.apache.flink.runtime.rest.handler.async中的类
Message headers for the triggering of an asynchronous operation.
AsynchronousOperationTriggerMessageHeaders() - 类 的构造器org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
 
asynchronousSnapshots - 类 中的变量org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
Flag to de/activate asynchronous snapshots.
AsyncSnapshotCallable<T> - org.apache.flink.runtime.state中的类
Base class that outlines the strategy for asynchronous snapshots.
AsyncSnapshotCallable() - 类 的构造器org.apache.flink.runtime.state.AsyncSnapshotCallable
 
AsyncSnapshotCallable.AsyncSnapshotTask - org.apache.flink.runtime.state中的类
FutureTask that wraps a AsyncSnapshotCallable and connects it with cancellation and closing.
AtomicDisposableReferenceCounter - org.apache.flink.runtime.util中的类
Atomic reference counter, which enters a "disposed" state after it reaches a configurable reference count (default 0).
AtomicDisposableReferenceCounter() - 类 的构造器org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicDisposableReferenceCounter(int) - 类 的构造器org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
attachJobGraph(List<JobVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
attemptNumber() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
available() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
available() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
availableMemory - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The free memory segments currently available to the hash join.
awaitStartOfSuperstepOrTermination(int) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 

B

back() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
BackendBuildingException - org.apache.flink.runtime.state中的异常错误
Exceptions which indicate that a state backend building has failed.
BackendBuildingException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.state.BackendBuildingException
 
BackendBuildingException(String) - 异常错误 的构造器org.apache.flink.runtime.state.BackendBuildingException
 
BackendWritableBroadcastState<K,V> - org.apache.flink.runtime.state中的接口
An interface with methods related to the interplay between the Broadcast State and the OperatorStateBackend.
BackPressureStatsTracker - org.apache.flink.runtime.rest.handler.legacy.backpressure中的接口
Interface for a tracker of back pressure statistics for ExecutionJobVertex.
BackPressureStatsTrackerImpl - org.apache.flink.runtime.rest.handler.legacy.backpressure中的类
Back pressure statistics tracker.
BackPressureStatsTrackerImpl(StackTraceSampleCoordinator, int, int, int, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Creates a back pressure statistics tracker.
BatchTask<S extends org.apache.flink.api.common.functions.Function,OT> - org.apache.flink.runtime.operators中的类
The base class for all batch tasks.
BatchTask(Environment) - 类 的构造器org.apache.flink.runtime.operators.BatchTask
Create an Invokable task and set its environment.
bestEffortDiscardAllStateObjects(Iterable<? extends StateObject>) - 类 中的静态方法org.apache.flink.runtime.state.StateUtil
Iterates through the passed state handles and calls discardState() on each handle that is not null.
bestEffortGetNumOfUsedBuffers() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number of used buffers of this buffer pool.
bindVariables(String[], String[]) - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
BitSet - org.apache.flink.runtime.operators.util中的类
 
BitSet(int) - 类 的构造器org.apache.flink.runtime.operators.util.BitSet
 
bitSet - 类 中的变量org.apache.flink.runtime.operators.util.BloomFilter
 
BitSet(int) - 类 的构造器org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
bitSize() - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
Number of bits
bitSize() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Number of bits
BlobCacheService - org.apache.flink.runtime.blob中的类
The BLOB cache provides access to BLOB services for permanent and transient BLOBs.
BlobCacheService(Configuration, BlobView, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.blob.BlobCacheService
Instantiates a new BLOB cache.
BlobCacheService(PermanentBlobCache, TransientBlobCache) - 类 的构造器org.apache.flink.runtime.blob.BlobCacheService
Instantiates a new BLOB cache.
BlobClient - org.apache.flink.runtime.blob中的类
The BLOB client can communicate with the BLOB server and either upload (PUT), download (GET), or delete (DELETE) BLOBs.
BlobClient(InetSocketAddress, Configuration) - 类 的构造器org.apache.flink.runtime.blob.BlobClient
Instantiates a new BLOB client.
blobClientConfig - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Configuration for the blob client like ssl parameters required to connect to the blob server.
BlobKey - org.apache.flink.runtime.blob中的类
A BLOB key uniquely identifies a BLOB.
BlobKey(BlobKey.BlobType) - 类 的构造器org.apache.flink.runtime.blob.BlobKey
Constructs a new BLOB key.
BlobKey(BlobKey.BlobType, byte[]) - 类 的构造器org.apache.flink.runtime.blob.BlobKey
Constructs a new BLOB key from the given byte array.
BlobKey(BlobKey.BlobType, byte[], byte[]) - 类 的构造器org.apache.flink.runtime.blob.BlobKey
Constructs a new BLOB key from the given byte array.
BlobLibraryCacheManager - org.apache.flink.runtime.execution.librarycache中的类
Provides facilities to download a set of libraries (typically JAR files) for a job from a PermanentBlobService and create a class loader with references to them.
BlobLibraryCacheManager(PermanentBlobService, FlinkUserCodeClassLoaders.ResolveOrder, String[]) - 类 的构造器org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
BlobServer - org.apache.flink.runtime.blob中的类
This class implements the BLOB server.
BlobServer(Configuration, BlobStore) - 类 的构造器org.apache.flink.runtime.blob.BlobServer
Instantiates a new BLOB server and binds it to a free network port.
BlobServerProtocol - org.apache.flink.runtime.blob中的类
Defines constants for the protocol between the BLOB server and the caches.
BlobService - org.apache.flink.runtime.blob中的接口
A simple store and retrieve binary large objects (BLOBs).
BlobStore - org.apache.flink.runtime.blob中的接口
A blob store.
BlobStoreService - org.apache.flink.runtime.blob中的接口
Service interface for the BlobStore which allows to close and clean up its data.
BlobUtils - org.apache.flink.runtime.blob中的类
Utility class to work with blob data.
blobView - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Blob store for distributed file storage, e.g. in HA.
BlobView - org.apache.flink.runtime.blob中的接口
View on blobs stored in a BlobStore.
BlobWriter - org.apache.flink.runtime.blob中的接口
BlobWriter is used to upload data to the BLOB store.
BlockChannelReader<T> - org.apache.flink.runtime.io.disk.iomanager中的接口
A reader that reads data in blocks from a file channel.
BlockChannelWriter<T> - org.apache.flink.runtime.io.disk.iomanager中的接口
A writer that writes data in blocks to a file channel.
BlockChannelWriterWithCallback<T> - org.apache.flink.runtime.io.disk.iomanager中的接口
 
blockHeadCopy - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
BlockingBackChannel - org.apache.flink.runtime.iterative.concurrent中的类
A concurrent datastructure that establishes a backchannel buffer between an iteration head and an iteration tail.
BlockingBackChannel(SerializedUpdateBuffer) - 类 的构造器org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
 
BlockingBackChannelBroker - org.apache.flink.runtime.iterative.concurrent中的类
Singleton class for the threadsafe handover of BlockingBackChannels from iteration heads to iteration tails.
BlockResettableMutableObjectIterator<T> - org.apache.flink.runtime.operators.resettable中的类
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
BlockResettableMutableObjectIterator(MemoryManager, MutableObjectIterator<T>, TypeSerializer<T>, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
BloomFilter - org.apache.flink.runtime.operators.util中的类
BloomFilter is a probabilistic data structure for set membership check.
BloomFilter(int, int) - 类 的构造器org.apache.flink.runtime.operators.util.BloomFilter
 
BloomFilter.BitSet - org.apache.flink.runtime.operators.util中的类
Bare metal bit set implementation.
BootstrapTools - org.apache.flink.runtime.clusterframework中的类
Tools for starting JobManager and TaskManager processes, including the Actor Systems used to run the JobManager and TaskManager actors.
BootstrapTools.FixedThreadPoolExecutorConfiguration - org.apache.flink.runtime.clusterframework中的类
Configuration for a fixed thread pool executor.
BootstrapTools.ForkJoinExecutorConfiguration - org.apache.flink.runtime.clusterframework中的类
Configuration for a fork join executor.
BoundedInputStream - org.apache.flink.runtime.state中的类
Wrapper around a FSDataInputStream to limit the maximum read offset.
BoundedInputStream(FSDataInputStream, long) - 类 的构造器org.apache.flink.runtime.state.BoundedInputStream
 
broadcastEmit(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
This is used to broadcast Streaming Watermarks in-band with records.
broadcastEvent(AbstractEvent) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
broadcastInputReaders - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The input readers for the configured broadcast variables for this task.
broadcastInputSerializers - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The serializers for the broadcast input data types.
BroadcastRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
A special record-oriented runtime result writer only for broadcast mode.
BroadcastRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - 类 的构造器org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
 
BroadcastVariableKey - org.apache.flink.runtime.broadcast中的类
An identifier for a BroadcastVariableMaterialization based on the task's JobVertexID, broadcast variable name and iteration superstep.
BroadcastVariableKey(JobVertexID, String, int) - 类 的构造器org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
BroadcastVariableManager - org.apache.flink.runtime.broadcast中的类
The BroadcastVariableManager is used to manage the materialization of broadcast variables.
BroadcastVariableManager() - 类 的构造器org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
BroadcastVariableMaterialization<T,C> - org.apache.flink.runtime.broadcast中的类
This class represents a single materialization of a broadcast variable and maintains a reference count for it.
BroadcastVariableMaterialization(BroadcastVariableKey) - 类 的构造器org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
Broker<V> - org.apache.flink.runtime.iterative.concurrent中的类
A concurrent data structure that allows the hand-over of an object between a pair of threads.
Broker() - 类 的构造器org.apache.flink.runtime.iterative.concurrent.Broker
 
brokerKey() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
buckets - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The array of memory segments that contain the buckets which form the actual hash-table of hash-codes and pointers to the elements.
bucketsPerSegmentBits - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The number of bits that describe the position of a bucket in a memory segment.
bucketsPerSegmentMask - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The number of hash table buckets in a single memory segment - 1.
Buffer - org.apache.flink.runtime.io.network.buffer中的接口
Wrapper for pooled MemorySegment instances with reference counting.
buffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
buffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
buffer - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
buffer - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
BufferAndAvailability(Buffer, boolean, int) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
BufferAndBacklog(Buffer, boolean, int, boolean) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
BufferAvailabilityListener - org.apache.flink.runtime.io.network.partition中的接口
Listener interface implemented by consumers of ResultSubpartitionView that want to be notified of availability of further buffers.
BufferBuilder - org.apache.flink.runtime.io.network.buffer中的类
Not thread safe class for filling in the content of the MemorySegment.
BufferBuilder(MemorySegment, BufferRecycler) - 类 的构造器org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
BufferConsumer - org.apache.flink.runtime.io.network.buffer中的类
Not thread safe class for producing Buffer.
BufferConsumer(MemorySegment, BufferRecycler, BufferBuilder.PositionMarker) - 类 的构造器org.apache.flink.runtime.io.network.buffer.BufferConsumer
Constructs BufferConsumer instance with content that can be changed by BufferBuilder.
BufferConsumer(MemorySegment, BufferRecycler, boolean) - 类 的构造器org.apache.flink.runtime.io.network.buffer.BufferConsumer
Constructs BufferConsumer instance with static content.
BufferFileChannelReader - org.apache.flink.runtime.io.disk.iomanager中的类
Helper class to read Buffers from files into objects.
BufferFileReader - org.apache.flink.runtime.io.disk.iomanager中的接口
 
BufferFileSegmentReader - org.apache.flink.runtime.io.disk.iomanager中的接口
 
BufferFileWriter - org.apache.flink.runtime.io.disk.iomanager中的接口
 
BufferListener - org.apache.flink.runtime.io.network.buffer中的接口
Interface of the availability of buffers.
BufferListener.NotificationResult - org.apache.flink.runtime.io.network.buffer中的枚举
Status of the notification result from the buffer listener.
BufferOrEvent - org.apache.flink.runtime.io.network.partition.consumer中的类
Either type for Buffer or AbstractEvent instances tagged with the channel index, from which they were received.
BufferOrEvent(Buffer, int) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferOrEvent(AbstractEvent, int) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferPool - org.apache.flink.runtime.io.network.buffer中的接口
A dynamically sized buffer pool.
BufferPoolFactory - org.apache.flink.runtime.io.network.buffer中的接口
A factory for buffer pools.
BufferPoolOwner - org.apache.flink.runtime.io.network.buffer中的接口
Interface for releasing memory buffers.
BufferProvider - org.apache.flink.runtime.io.network.buffer中的接口
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
BufferRecycler - org.apache.flink.runtime.io.network.buffer中的接口
Interface for recycling MemorySegments.
buffers - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultSubpartition
All buffers of this subpartition.
buffersInBacklog() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
buffersInBacklog() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
build() - 类 中的方法org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
build() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
build() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
build() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
build() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
 
build() - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder
 
build() - 接口 中的方法org.apache.flink.runtime.state.StateBackendBuilder
 
build() - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
 
buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
Builder(OperatorSubtaskState, List<OperatorSubtaskState>) - 类 的构造器org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
Builder(OperatorSubtaskState, List<OperatorSubtaskState>, boolean) - 类 的构造器org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.jobmaster.JobResult.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
Builder() - 类 的构造器org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
 
BuildFirstCachedJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
BuildFirstCachedJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.BuildFirstCachedJoinDriver
 
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, BlobWriter, Time, Logger) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
Builds the ExecutionGraph from the JobGraph.
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, int, BlobWriter, Time, Logger) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
已过时。
buildInitialTable(MutableObjectIterator<BT>) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Creates the initial hash table.
BuildSecondCachedJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
BuildSecondCachedJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.BuildSecondCachedJoinDriver
 
buildSideComparator - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The utilities to hash and compare the build side data types.
buildSideComparator - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to hash and compare the build side data types.
buildSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The utilities to serialize the build side data types.
buildSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to serialize the build side data types.
buildTableFromSpilledPartition(HashPartition<BT, PT>) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
buildTableWithUniqueKey(MutableObjectIterator<T>) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
BulkBlockChannelReader - org.apache.flink.runtime.io.disk.iomanager中的接口
 
bytes() - 类 中的方法org.apache.flink.runtime.checkpoint.MasterState
 
ByteStreamStateHandle - org.apache.flink.runtime.state.memory中的类
A state handle that contains stream state in a byte array.
ByteStreamStateHandle(String, byte[]) - 类 的构造器org.apache.flink.runtime.state.memory.ByteStreamStateHandle
Creates a new ByteStreamStateHandle containing the given data.

C

cachable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
cachable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
calculateCutoffMB(Configuration, long) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers based on the total memory to use and the according configuration parameters.
calculateNetworkBufferMemory(TaskManagerServicesConfiguration, long) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers inside the current JVM instance based on the available heap or the max heap size and the according configuration parameters.
calculatePreferredLocations(LocationPreferenceConstraint) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Calculates the preferred locations based on the location preference constraint.
call() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
 
callAsync(Callable<V>, Time) - 接口 中的方法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 - org.apache.flink.runtime.rpc.messages中的类
Message for asynchronous callable invocations
CallAsync(Callable<?>) - 类 的构造器org.apache.flink.runtime.rpc.messages.CallAsync
 
callAsync(Callable<V>, Time) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
callAsyncWithoutFencing(Callable<V>, Time) - 接口 中的方法org.apache.flink.runtime.rpc.FencedMainThreadExecutable
Run the given callable in the main thread without attaching a fencing token.
callAsyncWithoutFencing(Callable<V>, Time) - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
Run the given callable in the main thread of the RpcEndpoint without checking the fencing token.
callInternal() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
This method implements the (async) snapshot logic.
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法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>) - 接口 中的方法org.apache.flink.runtime.operators.util.JoinTaskIterator
Moves the internal pointer to the next key that both inputs share.
canBeReleased() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
canBeReleased() - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Checks whether the task executor can be released.
canBeSubsumed() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
cancel() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
cancel() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
cancel() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
cancel() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Cancels this ExecutionVertex.
cancel() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
cancel() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
cancel(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Cancels the currently executed job.
cancel() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.DataSinkTask
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.DataSourceTask
 
cancel() - 接口 中的方法org.apache.flink.runtime.operators.Driver
This method is invoked when the driver must aborted in mid processing.
cancel() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
cancel() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
cancel() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistration
Cancels the registration procedure.
cancel(boolean) - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
 
cancel() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
 
cancel(boolean) - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
cancelAndReleaseAllSlots() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
cancelChainedTasks(List<ChainedDriver<?, ?>>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Cancels all tasks via their ChainedDriver.cancelTask() method.
CancelCheckpointMarker - 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) - 类 的构造器org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
cancelCleanupTask() - 类 中的方法org.apache.flink.runtime.blob.AbstractBlobCache
Cancels any cleanup task that subclasses may be executing.
cancelCleanupTask() - 类 中的方法org.apache.flink.runtime.blob.PermanentBlobCache
 
cancelCleanupTask() - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
cancelExecution() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Cancels the task execution.
cancelJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
cancelJob(JobID) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
cancelJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Cancel the given job.
cancelRequestFor(InputChannelID) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkClientHandler
 
cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Cancels the slot request with the given SlotRequestId and SlotSharingGroupId.
cancelSlotRequest(AllocationID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
cancelSlotRequest(AllocationID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Cancel the slot allocation requests from the resource manager.
cancelStackTraceSample(int, Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Cancels a pending sample.
cancelStreamRegistry - 类 中的变量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 - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
cancelStreamRegistry - 类 中的变量org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
 
cancelTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
cancelTask(ExecutionAttemptID, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Cancel the given task.
cancelTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
cancelTask() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
cancelTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
cancelTask(ExecutionAttemptID, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Cancel the given task.
CancelTaskException - org.apache.flink.runtime.execution中的异常错误
Thrown to trigger a canceling of the executing task.
CancelTaskException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException(String) - 异常错误 的构造器org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException() - 异常错误 的构造器org.apache.flink.runtime.execution.CancelTaskException
 
cancelWithFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
canEqual(Object) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
canRestart() - 接口 中的方法org.apache.flink.runtime.executiongraph.restart.RestartStrategy
True if the restart strategy can be applied to restart the ExecutionGraph.
capacity() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
capacity(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
CaseInsensitiveOrderComparator() - 类 的构造器org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
 
ChainedAllReduceDriver<IT> - org.apache.flink.runtime.operators.chaining中的类
 
ChainedAllReduceDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
ChainedDriver<IT,OT> - 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() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedDriver
 
ChainedFlatMapDriver<IT,OT> - org.apache.flink.runtime.operators.chaining中的类
 
ChainedFlatMapDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
ChainedMapDriver<IT,OT> - org.apache.flink.runtime.operators.chaining中的类
 
ChainedMapDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
ChainedReduceCombineDriver<T> - org.apache.flink.runtime.operators.chaining中的类
Chained version of ReduceCombineDriver.
ChainedReduceCombineDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
ChainedStateHandle<T extends StateObject> - org.apache.flink.runtime.state中的类
Handle to state handles for the operators in an operator chain.
ChainedStateHandle(List<? extends T>) - 类 的构造器org.apache.flink.runtime.state.ChainedStateHandle
Wraps a list to the state handles for the operators in a chain.
chainedTasks - 类 中的变量org.apache.flink.runtime.operators.BatchTask
A list of chained drivers, if there are any.
ChainedTerminationCriterionDriver<IT,OT> - org.apache.flink.runtime.operators.chaining中的类
 
ChainedTerminationCriterionDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
channelIndex - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
channelRead0(ChannelHandlerContext, HttpObject) - 类 中的方法org.apache.flink.runtime.rest.FileUploadHandler
 
channelRead0(ChannelHandlerContext, RoutedRequest) - 类 中的方法org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
channelRead0(ChannelHandlerContext, RoutedRequest) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - 类 中的方法org.apache.flink.runtime.rest.handler.PipelineErrorHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouterHandler
 
ChannelReaderInputView - 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) - 类 的构造器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) - 类 的构造器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> - 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) - 类 的构造器org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - 类 的构造器org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - 类 的构造器org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(ChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - 类 的构造器org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - 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) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
ChannelWriterOutputView - 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) - 类 的构造器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) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Creates an new ChannelWriterOutputView that writes to the given channel.
CheckAndAllocateContainers - org.apache.flink.runtime.clusterframework.messages中的类
This message signals the resource master to check how many TaskManagers are desired, how many are available, and to trigger adjustments if needed.
checkErroneous() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Checks the exception state of this channel.
checkError() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Checks for an error and rethrows it if one was reported.
checkNetworkBufferConfig(int, float, long, long) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (new) network buffer configuration.
checkNetworkConfigOld(int) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (old) network buffer configuration.
checkNotShutdown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
checkParallelismPreconditions(List<OperatorState>, ExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
checkParallelismPreconditions(int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
 
CHECKPOINT_DIR_PREFIX - 类 中的静态变量org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The prefix of the directory containing the data exclusive to a checkpoint.
CHECKPOINT_SHARED_STATE_DIR - 类 中的静态变量org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The name of the directory for shared checkpoint state.
CHECKPOINT_TASK_OWNED_STATE_DIR - 类 中的静态变量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) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
CheckpointAlignment(MinMaxAvgStatistics, MinMaxAvgStatistics) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
CheckpointBarrier - org.apache.flink.runtime.io.network.api中的类
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
CheckpointBarrier(long, long, CheckpointOptions) - 类 的构造器org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
CheckpointConfigHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
 
CheckpointConfigHeaders - org.apache.flink.runtime.rest.messages.checkpoints中的类
Message headers for the CheckpointConfigHandler.
CheckpointConfigInfo - org.apache.flink.runtime.rest.messages.checkpoints中的类
Response class of the CheckpointConfigHandler.
CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode, long, long, long, int, CheckpointConfigInfo.ExternalizedCheckpointInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
CheckpointConfigInfo.ExternalizedCheckpointInfo - org.apache.flink.runtime.rest.messages.checkpoints中的类
Contains information about the externalized checkpoint configuration.
CheckpointConfigInfo.ProcessingMode - org.apache.flink.runtime.rest.messages.checkpoints中的枚举
Processing mode.
CheckpointConfigInfo.ProcessingModeDeserializer - org.apache.flink.runtime.rest.messages.checkpoints中的类
Processing mode deserializer.
CheckpointConfigInfo.ProcessingModeSerializer - org.apache.flink.runtime.rest.messages.checkpoints中的类
CheckpointCoordinator - org.apache.flink.runtime.checkpoint中的类
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
CheckpointCoordinator(JobID, long, long, long, int, CheckpointRetentionPolicy, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, SharedStateRegistryFactory) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
CheckpointCoordinatorConfiguration - org.apache.flink.runtime.jobgraph.tasks中的类
Configuration settings for the CheckpointCoordinator.
CheckpointCoordinatorConfiguration(long, long, long, int, CheckpointRetentionPolicy, boolean) - 类 的构造器org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
CheckpointCoordinatorDeActivator - org.apache.flink.runtime.checkpoint中的类
This actor listens to changes in the JobStatus and activates or deactivates the periodic checkpoint scheduler.
CheckpointCoordinatorDeActivator(CheckpointCoordinator) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
CheckpointCoordinatorGateway - org.apache.flink.runtime.checkpoint中的接口
 
CheckpointDeclineException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Base class of all exceptions that indicate a declined checkpoint.
CheckpointDeclineException(String) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineOnCancellationBarrierException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because a cancellation barrier was received.
CheckpointDeclineOnCancellationBarrierException() - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineOnCancellationBarrierException
 
CheckpointDeclineReason - org.apache.flink.runtime.checkpoint中的枚举
Various reasons why a checkpoint was declined.
CheckpointDeclineSubsumedException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because a newer checkpoint barrier was received on an input before the pending checkpoint's barrier.
CheckpointDeclineSubsumedException(long) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineSubsumedException
 
CheckpointDeclineTaskNotCheckpointingException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because a task does not support checkpointing.
CheckpointDeclineTaskNotCheckpointingException(String) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotCheckpointingException
 
CheckpointDeclineTaskNotReadyException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because a task was not ready to perform a checkpoint.
CheckpointDeclineTaskNotReadyException(String) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotReadyException
 
CheckpointDuration(long, long) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
CheckpointDuration(MinMaxAvgStatistics, MinMaxAvgStatistics) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
CheckpointedStateScope - org.apache.flink.runtime.state中的枚举
The scope for a chunk of checkpointed state.
CheckpointException - org.apache.flink.runtime.checkpoint中的异常错误
Base class for checkpoint related exceptions.
CheckpointException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException(String) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception indicating a problem with checkpointing on the TaskExecutor side.
CheckpointException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointIDCounter - org.apache.flink.runtime.checkpoint中的接口
A checkpoint ID counter.
CheckpointIdPathParameter - org.apache.flink.runtime.rest.messages.checkpoints中的类
Path parameter for the checkpoint id of type Long.
CheckpointIdPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
checkpointIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
 
checkpointIdToPath(long) - 类 中的静态方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Convert a checkpoint id into a ZooKeeper path.
CheckpointingStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
CheckpointingStatistics(CheckpointingStatistics.Counts, CheckpointingStatistics.Summary, CheckpointingStatistics.LatestCheckpoints, List<CheckpointStatistics>) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
CheckpointingStatistics.Counts - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint counts.
CheckpointingStatistics.LatestCheckpoints - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics about the latest checkpoints.
CheckpointingStatistics.RestoredCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics for a restored checkpoint.
CheckpointingStatistics.Summary - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint summary.
CheckpointingStatisticsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
 
CheckpointingStatisticsHeaders - org.apache.flink.runtime.rest.messages.checkpoints中的类
Message headers for the CheckpointingStatisticsHandler.
CheckpointingStatisticsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
CheckpointListener - 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 - org.apache.flink.runtime.rest.messages.checkpoints中的类
Message parameters for checkpoint related messages.
CheckpointMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
 
CheckpointMetaData - org.apache.flink.runtime.checkpoint中的类
Encapsulates all the meta data for a checkpoint.
CheckpointMetaData(long, long) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
CheckpointMetadataOutputStream - org.apache.flink.runtime.state中的类
An output stream for checkpoint metadata.
CheckpointMetadataOutputStream() - 类 的构造器org.apache.flink.runtime.state.CheckpointMetadataOutputStream
 
CheckpointMetrics - org.apache.flink.runtime.checkpoint中的类
A collection of simple metrics, around the triggering of a checkpoint.
CheckpointMetrics() - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
CheckpointMetrics(long, long, long, long) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
CheckpointOptions - org.apache.flink.runtime.checkpoint中的类
Options for performing the checkpoint.
CheckpointOptions(CheckpointType, CheckpointStorageLocationReference) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointOptions
 
CheckpointProperties - org.apache.flink.runtime.checkpoint中的类
The configuration of a checkpoint.
CheckpointRecoveryFactory - org.apache.flink.runtime.checkpoint中的接口
A factory for per Job checkpoint recovery components.
CheckpointResponder - org.apache.flink.runtime.taskmanager中的接口
Responder for checkpoint acknowledge and decline messages in the Task.
CheckpointRetentionPolicy - org.apache.flink.runtime.checkpoint中的枚举
Policy for whether checkpoints are retained after a job terminates.
Checkpoints - 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>) - 类 中的静态方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CheckpointStateOutputStream() - 类 的构造器org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
 
CheckpointStatisticDetailsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
 
CheckpointStatisticDetailsHeaders - org.apache.flink.runtime.rest.messages.checkpoints中的类
CheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics for a checkpoint.
CheckpointStatistics.CompletedCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics for a completed checkpoint.
CheckpointStatistics.FailedCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics for a failed checkpoint.
CheckpointStatistics.PendingCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Statistics for a pending checkpoint.
CheckpointStatsCache - org.apache.flink.runtime.rest.handler.job.checkpoints中的类
A size-based cache of accessed checkpoints for completed and failed checkpoints.
CheckpointStatsCache(int) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
 
CheckpointStatsCounts - org.apache.flink.runtime.checkpoint中的类
Counts of checkpoints.
CheckpointStatsHistory - org.apache.flink.runtime.checkpoint中的类
An array based history of checkpoint stats.
CheckpointStatsSnapshot - org.apache.flink.runtime.checkpoint中的类
A snapshot of the checkpoint stats.
CheckpointStatsStatus - org.apache.flink.runtime.checkpoint中的枚举
Status of the tracked checkpoint.
CheckpointStatsTracker - org.apache.flink.runtime.checkpoint中的类
Tracker for checkpoint statistics.
CheckpointStatsTracker(int, List<ExecutionJobVertex>, CheckpointCoordinatorConfiguration, MetricGroup) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new checkpoint stats tracker.
CheckpointStorage - org.apache.flink.runtime.state中的接口
CheckpointStorage implements the durable storage of checkpoint data and metadata streams.
CheckpointStorageLocation - org.apache.flink.runtime.state中的接口
A storage location for one particular checkpoint, offering data persistent, metadata persistence, and lifecycle/cleanup methods.
CheckpointStorageLocationReference - org.apache.flink.runtime.state中的类
A reference to a storage location.
CheckpointStorageLocationReference(byte[]) - 类 的构造器org.apache.flink.runtime.state.CheckpointStorageLocationReference
Creates a new location reference.
CheckpointStreamFactory - org.apache.flink.runtime.state中的接口
A factory for checkpoint output streams, which are used to persist data for checkpoints.
CheckpointStreamFactory.CheckpointStateOutputStream - org.apache.flink.runtime.state中的类
A dedicated output stream that produces a StreamStateHandle when closed.
CheckpointStreamWithResultProvider - org.apache.flink.runtime.state中的接口
Interface that provides access to a CheckpointStateOutputStream and a method to provide the SnapshotResult.
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream - org.apache.flink.runtime.state中的类
Implementation of CheckpointStreamWithResultProvider that creates both, the primary/remote/jm-owned state and the secondary/local/tm-owned state.
CheckpointStreamWithResultProvider.PrimaryStreamOnly - org.apache.flink.runtime.state中的类
Implementation of CheckpointStreamWithResultProvider that only creates the primary/remote/jm-owned state.
CheckpointTriggerException - org.apache.flink.runtime.checkpoint中的异常错误
Exceptions which indicate that a checkpoint triggering has failed.
CheckpointTriggerException(String, CheckpointDeclineReason) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointTriggerException
 
CheckpointTriggerResult - org.apache.flink.runtime.checkpoint中的类
The result of triggering a checkpoint.
CheckpointType - org.apache.flink.runtime.checkpoint中的枚举
The type of checkpoint to perform.
checkStateMetaInfo(StateDescriptor<?, ?>) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
childFirst(URL[], ClassLoader, String[]) - 类 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
CircularElement() - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularElement(int, InMemorySorter<E>, List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularQueues() - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
CircularQueues(int) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
ClassLoaderUtil - 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 - org.apache.flink.runtime.jobmaster.message中的类
The response of classloading props request to JobManager.
ClassloadingProps(int, Collection<PermanentBlobKey>, Collection<URL>) - 类 的构造器org.apache.flink.runtime.jobmaster.message.ClassloadingProps
Constructor of ClassloadingProps.
cleanup() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
cleanup() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
cleanup() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
cleanup() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
Perform the cleanup of out dated ExecutionGraphEntry.
cleanup() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Removes all BLOBs from local and HA store belonging to the given job ID.
cleanUpOperatorStatsCache() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Cleans up the operator stats cache if it contains timed out entries.
cleanUpOperatorStatsCache() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Cleans up the operator stats cache if it contains timed out entries.
cleanupProvidedResources() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
This method implements the cleanup of resources that have been passed in (from the sync part).
clear() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
clear() - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
clear() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
clear() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
clear() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
clear() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Clears the internal state of the view.
clear() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
Clears the internal state.
clear() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Removes all entries from the PriorityQueue.
clear() - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
Clear the bit set.
clear() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Clear the bit set.
clear() - 类 中的方法org.apache.flink.runtime.query.KvStateEntry
 
clear() - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop and clear the currently registered job leader id listeners.
clear() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
Clears the queue.
clear() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
 
clear() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
 
clear() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
clear() - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
clear() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Removes all tasks from this task slot.
clear() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
clear() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
clear() - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
clearAll() - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
Removes all registered event handlers.
clearAllBroadcastVariables() - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
clearAllMemory(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
clearAllMemory(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
releases all of the partition's segments (pages and overflow buckets)
clearAllMemory(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
clearBroadcastVariable(String) - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
clearBuffers() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.MutableReader
 
clearBuffers() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
 
clearBuffers() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.Reader
 
clearBuffers() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.RecordReader
 
clearBuffers() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
clearJob(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
clearJob(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
clearJob(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.RunningJobsRegistry
Clear job state form the registry, usually called after job finish.
clearJob(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
clearPartitions() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
This method clears all partitions currently residing (partially) in memory.
clearPendingSlotRequest() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
clearReaders(MutableReader<?>[]) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
 
clearStateAsync() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
clearWriters(List<RecordWriter<?>>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
 
CLIENT_CONNECT_TIMEOUT_SECONDS - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
ClientUtils - org.apache.flink.runtime.client中的枚举
Contains utility methods for clients.
Clock - org.apache.flink.runtime.util.clock中的类
A clock that gives access to time.
Clock() - 类 的构造器org.apache.flink.runtime.util.clock.Clock
 
clone() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
 
cloneConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Clones the given configuration and resets instance specific config options.
close() - 类 中的方法org.apache.flink.runtime.blob.AbstractBlobCache
 
close() - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
 
close() - 类 中的方法org.apache.flink.runtime.blob.BlobClient
 
close() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Shuts down the BLOB server.
close() - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
close() - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
close(Collection<MasterTriggerRestoreHook<?>>, Logger) - 类 中的静态方法org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Closes the master hooks.
close() - 接口 中的方法org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Tear-down method for the hook.
close() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
close() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
close() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Closes the high availability services, releasing all resources.
close() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
close() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
close() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
close() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelInputView
 
close() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
Closes this output, writing pending data and releasing the memory.
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Closes the channel and waits until all pending asynchronous requests are processed.
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Closes this InputView, closing the underlying reader and returning all memory segments.
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Closes this OutputView, closing the underlying writer and returning all memory segments.
close() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Closes the channel.
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.RequestQueue
Closes this request queue.
close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
close() - 类 中的方法org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
close() - 类 中的方法org.apache.flink.runtime.io.disk.SpillingBuffer
 
close() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
Closes the writer.
close() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
close(RemoteInputChannel) - 类 中的方法org.apache.flink.runtime.io.network.netty.PartitionRequestClient
 
close() - 类 中的方法org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
close() - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
close() - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
close() - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
close() - 类 中的方法org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
close() - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
close() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
close() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
 
close() - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
close() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Closes the hash table.
close() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
Closes the hash table.
close() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Closes the hash table.
close() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
close() - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputCollector
 
close() - 类 中的方法org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.sort.LargeRecordHandler
Closes all structures and deletes all temporary files.
close() - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
close() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Shuts down all the threads initiated by this sort/merger.
close() - 类 中的方法org.apache.flink.runtime.operators.TempBarrier
 
close() - 接口 中的方法org.apache.flink.runtime.operators.util.CoGroupTaskIterator
General-purpose close method.
close() - 接口 中的方法org.apache.flink.runtime.operators.util.JoinTaskIterator
General-purpose close method.
close() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
close() - 类 中的方法org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
 
close() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
Close connection.
close() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Closes the slot manager.
close() - 类 中的方法org.apache.flink.runtime.rest.handler.FileUploads
 
close() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
 
close() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
close() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.CheckpointMetadataOutputStream
This method should close the stream, if has not been closed before.
close() - 类 中的方法org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
This method should close the stream, if has not been closed before.
close() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
close() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
close() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
close() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
close() - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
 
close() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
close() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
close() - 类 中的方法org.apache.flink.runtime.util.ForwardingOutputStream
 
close() - 类 中的方法org.apache.flink.runtime.util.NonClosingInputStreamDecorator
 
close() - 类 中的方法org.apache.flink.runtime.util.NonClosingOutpusStreamDecorator
 
close() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
close() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
close(boolean) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Closes the ZooKeeperUtilityFactory.
CloseableInputProvider<E> - org.apache.flink.runtime.operators.util中的接口
Utility interface for a provider of an input that can be closed.
closeAndCleanupAllData() - 接口 中的方法org.apache.flink.runtime.blob.BlobStoreService
Closes and cleans up the store.
closeAndCleanupAllData() - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
closeAndCleanupAllData() - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
closeAndCleanupAllData() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
closeAndCleanupAllData() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
closeAndDelete() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelInputView
 
closeAndDelete() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
Closes this output, writing pending data and releasing the memory.
closeAndDelete() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
closeAndDelete() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
This method waits for all pending asynchronous requests to return.
closeAndDelete() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Closes the channel and deletes the underlying file.
closeAndDelete() - 类 中的方法org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
closeAndFinalizeCheckpoint() - 类 中的方法org.apache.flink.runtime.state.CheckpointMetadataOutputStream
Closes the stream after all metadata was written and finalizes the checkpoint location.
closeAndFinalizeCheckpoint() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
closeAndFinalizeCheckpointStreamResult() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
Closes the stream ans returns a snapshot result with the stream handle(s).
closeAndFinalizeCheckpointStreamResult() - 类 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
 
closeAndFinalizeCheckpointStreamResult() - 类 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
 
closeAndGetBytes() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
Closes the stream and returns the byte array containing the stream's data.
closeAndGetHandle() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
closeAndGetHandle() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
closeAndGetHandle() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
closeAndGetHandle() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
closeAndGetPrimaryHandle() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
closeAndGetSecondaryHandle() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
closeAsync() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
closeAsync() - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
 
closeAsync() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
closeAsync() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
Shuts down the mini cluster, failing all currently executing jobs.
closeAsync() - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractHandler
 
closeAsync() - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
closeAsync() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
 
closeAsync() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Triggers the shut down of the rpc endpoint.
closeAsync() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
closeAsync() - 枚举 中的方法org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
 
closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Closes all chained tasks, in the order as they are stored in the array.
closed - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Flag marking this channel as closed
closed - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Flag to mark the table as open / closed.
closed - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
Flag indicating that the closing logic has been invoked.
closed - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Flag indicating that the sorter was closed.
closeHandlerAsync() - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractHandler
 
closeHandlerAsync() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
 
closeJobManagerConnection(JobID, Exception) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
closeLocalStrategiesAndCaches() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
closeLock - 类 中的变量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) - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
Closes opened ChannelConnections in case of a resource release.
closeOpenChannelConnections(ConnectionID) - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
closeOpenChannelConnections(ConnectionID) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
closeTask() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
closeTaskManagerConnection(ResourceID, Exception) - 类 中的方法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) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Closes the given stub using its RichFunction.close() method.
CLUSTER_CONFIG_REST_PATH - 类 中的静态变量org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
ClusterConfigHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
 
ClusterConfiguration - org.apache.flink.runtime.entrypoint中的类
Configuration class which contains the parsed command line arguments for the ClusterEntrypoint.
ClusterConfiguration(String, Properties, String[]) - 类 的构造器org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
clusterConfiguration - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
ClusterConfigurationInfo - org.apache.flink.runtime.rest.messages中的类
Response of the ClusterConfigHandler, represented as a list of key-value pairs of the cluster Configuration.
ClusterConfigurationInfo() - 类 的构造器org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
ClusterConfigurationInfo(int) - 类 的构造器org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
ClusterConfigurationInfoEntry - org.apache.flink.runtime.rest.messages中的类
A single key-value pair entry in the ClusterConfigurationInfo response.
ClusterConfigurationInfoEntry(String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
ClusterConfigurationInfoHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the ClusterConfigHandler.
ClusterConfigurationParserFactory - org.apache.flink.runtime.entrypoint中的类
Parser factory which generates a ClusterConfiguration from the given list of command line arguments.
ClusterConfigurationParserFactory() - 类 的构造器org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
 
ClusterEntrypoint - org.apache.flink.runtime.entrypoint中的类
Base class for the Flink cluster entry points.
ClusterEntrypoint(Configuration) - 类 的构造器org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
ClusterEntrypoint.ExecutionMode - org.apache.flink.runtime.entrypoint中的枚举
Execution mode of the MiniDispatcher.
ClusterEntrypointException - org.apache.flink.runtime.entrypoint中的异常错误
Exceptions thrown by the ClusterEntrypoint.
ClusterEntrypointException(String) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.ClusterEntrypointException
 
ClusterEntrypointException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.ClusterEntrypointException
 
ClusterEntrypointException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.ClusterEntrypointException
 
ClusterInformation - org.apache.flink.runtime.entrypoint中的类
Information about the cluster which is shared with the cluster components.
ClusterInformation(String, int) - 类 的构造器org.apache.flink.runtime.entrypoint.ClusterInformation
 
ClusterOverview - org.apache.flink.runtime.messages.webmonitor中的类
Response to the RequestStatusOverview message, carrying a description of the Flink cluster status.
ClusterOverview(int, int, int, int, int, int, int) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
ClusterOverview(int, int, int, JobsOverview, JobsOverview) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
ClusterOverview(ResourceOverview, JobsOverview) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
ClusterOverviewHandler - 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>) - 类 的构造器org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
 
ClusterOverviewHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the ClusterOverviewHandler.
ClusterOverviewWithVersion - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
ClusterOverviewWithVersion(int, int, int, JobsOverview, JobsOverview, String, String) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
CoGroupDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
CoGroup task which is executed by a Task Manager.
CoGroupDriver() - 类 的构造器org.apache.flink.runtime.operators.CoGroupDriver
 
CoGroupRawDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
CoGroupRawDriver() - 类 的构造器org.apache.flink.runtime.operators.CoGroupRawDriver
 
CoGroupRawDriver.SimpleIterable<IN> - org.apache.flink.runtime.operators中的类
 
CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - org.apache.flink.runtime.operators中的类
 
CoGroupTaskIterator<T1,T2> - 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> - org.apache.flink.runtime.operators中的类
 
CoGroupWithSolutionSetFirstDriver() - 类 的构造器org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
CoGroupWithSolutionSetSecondDriver() - 类 的构造器org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
collect(T) - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
collect(T) - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
collect(T) - 类 中的方法org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
collect(T) - 类 中的方法org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
collect(T) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
collect(IN) - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
collect(IN) - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
collect(IT) - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
collect(T) - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputCollector
Collects a record and emits it to all writers.
collect(OUT) - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Collects stack traces of a task.
CoLocationConstraint - org.apache.flink.runtime.jobmanager.scheduler中的类
A CoLocationConstraint manages the location of a set of tasks (Execution Vertices).
CoLocationGroup - 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() - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
CoLocationGroup(JobVertex...) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
combine(JobsOverview) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
Combines the given jobs overview with this.
combineAll(Collection<? extends CompletableFuture<? extends T>>) - 类 中的静态方法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) - 类 的构造器org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
 
CombiningUnilateralSortMerger<E> - 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) - 类 的构造器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) - 类 的构造器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 - org.apache.flink.runtime.operators.sort中的类
 
CommandLineOptions - org.apache.flink.runtime.entrypoint.parser中的类
Container class for command line options.
CommandLineParser<T> - org.apache.flink.runtime.entrypoint.parser中的类
Command line parser which produces a result from the given command line arguments.
CommandLineParser(ParserResultFactory<T>) - 类 的构造器org.apache.flink.runtime.entrypoint.parser.CommandLineParser
 
commit() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
Make the change visible to the readers.
commitDate - 类 中的变量org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
The git commit date
commitId - 类 中的变量org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
The git commit id (hash)
CompactingHashTable<T> - 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>) - 类 的构造器org.apache.flink.runtime.operators.hash.CompactingHashTable
 
CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.operators.hash.CompactingHashTable
 
CompactingHashTable.EntryIterator - 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> - org.apache.flink.runtime.operators.hash中的类
 
comparator - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
compare(int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
compare(int, int, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
compare(int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Compare items at the given addresses consistent with the semantics of Comparator.compare(Object, Object).
compare(int, int, int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Compare records at the given addresses consistent with the semantics of Comparator.compare(Object, Object).
compare(int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
compare(int, int, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
compare(String, String) - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
 
compare(Tuple2<RestHandlerSpecification, ChannelInboundHandler>, Tuple2<RestHandlerSpecification, ChannelInboundHandler>) - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
 
compare(RestAPIVersion, RestAPIVersion) - 类 中的方法org.apache.flink.runtime.rest.versioning.RestAPIVersion.RestAPIVersionComparator
 
comparePriority(T, T) - 接口 中的方法org.apache.flink.runtime.state.PriorityComparator
Compares two objects for priority.
comparePriorityTo(T) - 接口 中的方法org.apache.flink.runtime.state.PriorityComparable
 
compareTo(BlobKey) - 类 中的方法org.apache.flink.runtime.blob.BlobKey
 
compareTo(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
compareTo(Delayed) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
compareTo(TaskManagerLocation) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
complete() - 类 中的静态方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
 
completeAll(Collection<? extends CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Creates a FutureUtils.ConjunctFuture which is only completed after all given futures have completed.
completeAllocation(AllocationID, JobID) - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
completed(V) - 类 中的静态方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
completed() - 类 中的静态方法org.apache.flink.runtime.rest.messages.queue.QueueStatus
 
CompletedCheckpoint - 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) - 类 的构造器org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CompletedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>, String, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
CompletedCheckpointStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a successfully completed checkpoint.
CompletedCheckpointStatsSummary - org.apache.flink.runtime.checkpoint中的类
Summary over all completed checkpoints.
CompletedCheckpointStorageLocation - org.apache.flink.runtime.state中的接口
The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.
CompletedCheckpointStore - org.apache.flink.runtime.checkpoint中的接口
A bounded LIFO-queue of CompletedCheckpoint instances.
completedExceptionally(Throwable) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Returns an exceptionally completed CompletableFuture.
CompletedSubtaskCheckpointStatistics(int, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
completeExceptional(SerializedThrowable) - 类 中的静态方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
 
completeSnapshotAndGetHandle() - 类 中的方法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 - org.apache.flink.runtime.concurrent中的接口
Interface for an executor that runs tasks in the main thread of an RpcEndpoint.
ComponentMainThreadExecutor.DummyComponentMainThreadExecutor - org.apache.flink.runtime.concurrent中的类
Dummy implementation of ComponentMainThreadExecutor.
ComponentMainThreadExecutorServiceAdapter - org.apache.flink.runtime.concurrent中的类
Adapter class for a ScheduledExecutorService which shall be used as a ComponentMainThreadExecutor.
ComponentMainThreadExecutorServiceAdapter(ScheduledExecutorService, Runnable) - 类 的构造器org.apache.flink.runtime.concurrent.ComponentMainThreadExecutorServiceAdapter
 
ComponentMetricGroup<P extends AbstractMetricGroup<?>> - org.apache.flink.runtime.metrics.groups中的类
Abstract MetricGroup for system components (e.g., TaskManager, Job, Task, Operator).
ComponentMetricGroup(MetricRegistry, String[], P) - 类 的构造器org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Creates a new ComponentMetricGroup.
composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Run the given asynchronous action after the completion of the given future.
CompositeContainerOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
A composite overlay that delegates to a set of inner overlays.
CompositeContainerOverlay(ContainerOverlay...) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
CompositeContainerOverlay(List<ContainerOverlay>) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
compositeHeapBuffer() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
compositeHeapBuffer(int) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
CompositeStateHandle - org.apache.flink.runtime.state中的接口
Base of all snapshots that are taken by StateBackends and some other components in tasks.
computeDefaultMaxParallelism(int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes a default maximum parallelism from the operator parallelism.
computedResult - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
Cached result.
computeKeyGroupForKeyHash(int, int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
computeKeyGroupRangeForOperatorIndex(int, int, int) - 类 中的静态方法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) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Computes the memory size of the fraction per slot.
computeNumberOfPages(double) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Computes to how many pages the given number of bytes corresponds.
computeOperatorIndexForKeyGroup(int, int, int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes the index of the operator to which a key-group belongs under the given parallelism and maximum parallelism.
concat(String...) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(CharacterFilter, String...) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(Character, String...) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(CharacterFilter, Character, String...) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
Concatenates the given component names separated by the delimiter character.
concatScopes(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
config - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The task configuration with the setup parameters.
config - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
config - 类 中的变量org.apache.flink.runtime.operators.util.TaskConfig
 
CONFIG_DIR_OPTION - 类 中的静态变量org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
 
ConfigurableStateBackend - org.apache.flink.runtime.state中的接口
An interface for state backends that pick up additional parameters from a configuration.
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
configure(ContainerSpecification) - 接口 中的方法org.apache.flink.runtime.clusterframework.overlays.ContainerOverlay
Configure the given container specification.
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
configure(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
configure(Configuration, ClassLoader) - 接口 中的方法org.apache.flink.runtime.state.ConfigurableStateBackend
Creates a variant of the state backend that applies additional configuration parameters.
configure(Configuration, ClassLoader) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
confirmCheckpoint(long) - 接口 中的方法org.apache.flink.runtime.state.TaskLocalStateStore
Notifies that the checkpoint with the given id was confirmed as complete.
confirmCheckpoint(long) - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
confirmCheckpoint(ExecutionAttemptID, long, long) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
confirmCheckpoint(ExecutionAttemptID, long, long) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Confirm a checkpoint for the given task.
confirmLeaderSessionID(UUID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
confirmLeaderSessionID(UUID) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderElectionService
Confirms that the new leader session ID has been successfully received by the new leader.
confirmLeaderSessionID(UUID) - 类 中的方法org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
confirmLeaderSessionID(UUID) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
ConjunctFuture() - 类 的构造器org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
 
connecDataSet(IntermediateDataSet) - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
 
connect(String, Class<C>) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
connect(String, F, Class<C>) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
connect(String, Class<C>) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Connect to a remote rpc server under the provided address.
connect(String, F, Class<C>) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Connect to a remote fenced rpc server under the provided address.
CONNECT_BACKLOG - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
connectIdInput(IntermediateDataSetID, DistributionPattern) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
ConnectionClosedException - org.apache.flink.runtime.rest中的异常错误
Exception which is thrown if the RestClient detects that a connection was closed.
ConnectionClosedException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionClosedException
 
ConnectionClosedException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionClosedException
 
ConnectionClosedException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionClosedException
 
ConnectionException - org.apache.flink.runtime.rest中的异常错误
Base class for all connection related exception thrown by the RestClient.
ConnectionException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionException
 
ConnectionException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionException
 
ConnectionException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionException
 
ConnectionID - 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) - 类 的构造器org.apache.flink.runtime.io.network.ConnectionID
 
ConnectionID(InetSocketAddress, int) - 类 的构造器org.apache.flink.runtime.io.network.ConnectionID
 
ConnectionIdleException - org.apache.flink.runtime.rest中的异常错误
Exception which is thrown by the RestClient if a connection becomes idle.
ConnectionIdleException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionIdleException
 
ConnectionIdleException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionIdleException
 
ConnectionIdleException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.ConnectionIdleException
 
ConnectionManager - org.apache.flink.runtime.io.network中的接口
The connection manager manages physical connections for the (logical) remote input channels at runtime.
ConnectionUtils - org.apache.flink.runtime.net中的类
Utilities to determine the network interface and address that should be used to bind the TaskManager communication to.
ConnectionUtils() - 类 的构造器org.apache.flink.runtime.net.ConnectionUtils
 
ConnectionUtils.LeaderConnectingAddressListener - org.apache.flink.runtime.net中的类
A LeaderRetrievalListener that allows retrieving an InetAddress for the current leader.
connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
connectSource(int, IntermediateResult, JobEdge, int) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
connectToResourceManager(ResourceManagerGateway) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Connects the SlotPool to the given ResourceManager.
connectToResourceManager(ResourceManagerGateway) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
ConstantTextHandler - org.apache.flink.runtime.rest.handler.legacy中的类
Responder that returns a constant String.
ConstantTextHandler(String) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
 
constructLogString(String, String, AbstractInvokable) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Utility function that composes a string for logging purposes.
consume(T, int) - 接口 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner.KeyGroupElementsConsumer
 
consumeAndCacheRemainingData() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
ContaineredTaskManagerParameters - org.apache.flink.runtime.clusterframework中的类
This class describes the basic parameters for launching a TaskManager process.
ContaineredTaskManagerParameters(long, long, long, int, HashMap<String, String>) - 类 的构造器org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
ContainerOverlay - org.apache.flink.runtime.clusterframework.overlays中的接口
A container overlay to produce a container specification.
ContainerSpecification - org.apache.flink.runtime.clusterframework中的类
Encapsulates a container specification, including artifacts, environment variables, system properties, and Flink configuration settings.
ContainerSpecification() - 类 的构造器org.apache.flink.runtime.clusterframework.ContainerSpecification
 
ContainerSpecification.Artifact - org.apache.flink.runtime.clusterframework中的类
An artifact to be copied into the container.
ContainerSpecification.Artifact.Builder - org.apache.flink.runtime.clusterframework中的类
 
contains(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
contains(Object) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
contains(SlotRequestId) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
contains(AbstractID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
Checks whether this slot or any of its children contains the given groupId.
contains(AbstractID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
Check whether the task slot contains the given groupId.
contains(K) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
contains(int) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
Checks whether or not a single key-group is contained in the range.
contains(int) - 接口 中的方法org.apache.flink.runtime.state.KeyGroupsList
Returns true, if the given key group id is contained in the list, otherwise false.
contains(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerTable
 
containsAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
containsAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
containsJob(JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Check whether the given job is being monitored or not.
containsJob(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Check whether the service monitors the given job.
containsKey(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
containsKey(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
containsKey(N) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
containsKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
containsSlot(SlotID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
CONTENT_TYPE_BINARY - 枚举 中的静态变量org.apache.flink.runtime.rest.util.RestConstants
 
CONTENT_TYPE_JAR - 枚举 中的静态变量org.apache.flink.runtime.rest.util.RestConstants
 
ControlMessages - org.apache.flink.runtime.rpc.akka中的枚举
Control messages for the AkkaRpcActor.
ConversionException - org.apache.flink.runtime.rest.messages中的异常错误
Exception which is thrown if an input cannot be converted into the requested type.
ConversionException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.messages.ConversionException
 
ConversionException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.messages.ConversionException
 
ConversionException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.messages.ConversionException
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Converts the given string to a valid value of this parameter.
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageQueryParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
convertFromString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageQueryParameter
Converts the given string to a valid value of this parameter.
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
convertStringToValue(String) - 类 中的方法org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
已过时。
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
convertToString(Long) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
convertToString(Integer) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
 
convertToString(JobID) - 类 中的方法org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
convertToString(JobVertexID) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
convertToString(X) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Converts the given value to its string representation.
convertToString(List<X>) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageQueryParameter
 
convertToString(Integer) - 类 中的方法org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
convertToString(ResourceID) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
convertToString(TriggerId) - 类 中的方法org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
convertValueToString(Boolean) - 类 中的方法org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
convertValueToString(JobID) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
 
convertValueToString(MetricsAggregationParameter.AggregationMode) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
 
convertValueToString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
 
convertValueToString(String) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
 
convertValueToString(ResourceID) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
 
convertValueToString(X) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageQueryParameter
Converts the given value to its string representation.
convertValueToString(Integer) - 类 中的方法org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
convertValueToString(TerminationModeQueryParameter.TerminationMode) - 类 中的方法org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
copy() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
Returns a retained copy with separate indexes.
copy(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Create a copy of this QueryScopeInfo and append the given scope.
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
copy(String) - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
copy(ArrayList<T>) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
copy(ArrayList<T>, ArrayList<T>) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
copy(VoidNamespace) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(VoidNamespace, VoidNamespace) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy1 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
copy2 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
CopyOnWriteStateTable<K,N,S> - org.apache.flink.runtime.state.heap中的类
Implementation of Flink's in-memory state tables with copy-on-write support.
CopyOnWriteStateTable.StateTableEntry<K,N,S> - org.apache.flink.runtime.state.heap中的类
One entry in the CopyOnWriteStateTable.
CopyOnWriteStateTableSnapshot<K,N,S> - org.apache.flink.runtime.state.heap中的类
This class represents the snapshot of a CopyOnWriteStateTable and has a role in operator state checkpointing.
CopyOnWriteStateTableSnapshot.StateTableKeyGroupPartitioner<K,N,S> - org.apache.flink.runtime.state.heap中的类
This class is the implementation of KeyGroupPartitioner for CopyOnWriteStateTable.
CopyOnWriteStateTableSnapshot.TransformingStateTableKeyGroupPartitioner<K,N,S> - org.apache.flink.runtime.state.heap中的类
copyTemplate() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
copyToBufferBuilder(BufferBuilder) - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Copies the intermediate data serialization buffer to the given target buffer.
copyToBufferBuilder(BufferBuilder) - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
Copies an intermediate data serialization buffer into the target BufferBuilder.
CorruptConfigurationException - org.apache.flink.runtime.operators.util中的异常错误
Exception indicating that the parsed configuration was corrupt.
CorruptConfigurationException(String) - 异常错误 的构造器org.apache.flink.runtime.operators.util.CorruptConfigurationException
Creates a new exception with the given error message.
CorruptConfigurationException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.operators.util.CorruptConfigurationException
 
count - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
countBuffers() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
counter(int) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int, C) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String, C) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(int, C) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(String, C) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
CounterDump(QueryScopeInfo, String, long) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
counterHistogram - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
This bookkeeping array is used to count the elements in each key-group.
CountingCollector<OUT> - org.apache.flink.runtime.operators.util.metrics中的类
 
CountingCollector(Collector<OUT>, Counter) - 类 的构造器org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
CountingIterable<IN> - org.apache.flink.runtime.operators.util.metrics中的类
 
CountingIterable(Iterable<IN>, Counter) - 类 的构造器org.apache.flink.runtime.operators.util.metrics.CountingIterable
 
CountingIterator<IN> - org.apache.flink.runtime.operators.util.metrics中的类
 
CountingIterator(Iterator<IN>, Counter) - 类 的构造器org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
CountingMutableObjectIterator<IN> - org.apache.flink.runtime.operators.util.metrics中的类
 
CountingMutableObjectIterator(MutableObjectIterator<IN>, Counter) - 类 的构造器org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
Counts(long, long, int, long, long) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
create() - 类 中的方法org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
 
create() - 接口 中的方法org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
Instantiates the MasterTriggerRestoreHook.
create(Configuration, long, int) - 类 中的静态方法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) - 类 中的方法org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
 
create(Configuration, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, ArchivedExecutionGraphStore, MetricQueryServiceRetriever, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponentFactory
 
create(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[]) - 类 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
create(ExecutionGraph) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
Instantiates the FailoverStrategy.
create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment, TaskActions, TaskIOMetricGroup) - 类 中的静态方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Creates an input gate and all of its input channels.
create(JobGraph) - 类 中的方法org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
 
create(JobGraph) - 接口 中的方法org.apache.flink.runtime.jobmaster.factories.JobManagerJobMetricGroupFactory
create(JobGraph) - 枚举 中的方法org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
 
create(Collection<JobStatus>) - 类 中的静态方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
create(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
 
create(List<MemorySegment>) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorterFactory
Create an InMemorySorter instance with the given memory segments.
create(AccessExecution, MutableIOMetrics) - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
create(String, TypeSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
create(String, TypeSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory
 
create(int, int, KeyExtractorFunction<T>, PriorityComparator<T>) - 接口 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory
Creates a new queue for a given key-group partition.
create(String, TypeSerializer<T>) - 接口 中的方法org.apache.flink.runtime.state.PriorityQueueSetFactory
create(Executor) - 接口 中的方法org.apache.flink.runtime.state.SharedStateRegistryFactory
Factory method for SharedStateRegistry.
createActivatorDeactivator() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
createAllocatedSlotReport(ResourceID) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Create report about the allocated slots belonging to the specified task manager.
createAllocatedSlotReport(ResourceID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
createAndAddResultDataSet(ResultPartitionType) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
createAvailableOrEmbeddedServices(Configuration, Executor) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
createBlobStore() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Creates the BLOB store in which BLOBs are stored in a highly-available fashion.
createBlobStore() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
createBlobStore() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
createBlobStoreFromConfig(Configuration) - 类 中的静态方法org.apache.flink.runtime.blob.BlobUtils
Creates a BlobStore based on the parameters set in the configuration.
createBlockChannelReader(FileIOChannel.ID) - 类 中的方法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>) - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Creates a block channel reader that reads blocks from the given channel.
createBlockChannelWriter(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferConsumer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferFileWriter(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileWriter(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferPool(int, int) - 接口 中的方法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>) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
createBufferPool(int, int, Optional<BufferPoolOwner>) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - 类 中的方法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) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a new FileIOChannel.ID in one of the temp directories.
createChannelEnumerator() - 类 中的方法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() - 接口 中的方法org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Creates a the serializer to (de)serializes the data stored by this hook.
createCheckpointDirectory(Path, long) - 类 中的静态方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates the directory path for the data exclusive to a specific checkpoint.
createCheckpointIDCounter(JobID) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CheckpointIDCounter instance for a job.
createCheckpointIDCounter(JobID) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointIDCounter(JobID) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createCheckpointIDCounter(CuratorFramework, Configuration, JobID) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperCheckpointIDCounter instance.
createCheckpointStateOutputStream(CheckpointedStateScope) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStreamFactory
createCheckpointStateOutputStream(CheckpointedStateScope) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
createCheckpointStateOutputStream(CheckpointedStateScope) - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
createCheckpointStorage(JobID) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createCheckpointStorage(JobID) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createCheckpointStorage(JobID) - 接口 中的方法org.apache.flink.runtime.state.StateBackend
Creates a storage for checkpoints for the given job.
createCheckpointStore(JobID, int, ClassLoader) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CompletedCheckpointStore instance for a job.
createCheckpointStore(JobID, int, ClassLoader) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointStore(JobID, int, ClassLoader) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createChildGroup(String, AbstractMetricGroup.ChildType) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
createChildGroup(String, AbstractMetricGroup.ChildType) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
 
createClient() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
createClientSSLEngineFactory() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, Executor) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
createCopy(TypeSerializer<T>, T, T) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
created(JobResult) - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
createDetailsForJob(AccessExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherFactory
Create a Dispatcher of the given type T.
createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - 类 中的方法org.apache.flink.runtime.dispatcher.JobDispatcherFactory
 
createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - 枚举 中的方法org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
 
createDispatcherResourceManagerComponent(T, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - 类 中的方法org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
 
createDispatcherResourceManagerComponent(MiniDispatcher, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - 类 中的方法org.apache.flink.runtime.entrypoint.component.JobDispatcherResourceManagerComponentFactory
 
createDispatcherResourceManagerComponent(Dispatcher, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - 类 中的方法org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
 
createDispatcherResourceManagerComponentFactory(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createDispatcherResourceManagerComponentFactory(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
 
createDispatcherResourceManagerComponents(Configuration, MiniCluster.RpcServiceFactory, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, MetricQueryServiceRetriever, FatalErrorHandler) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalRecoveryDirectoryProvider) - 接口 中的静态方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
createExecutorService(int, int, String) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
createFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
createFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
Creates a FixedDelayRestartStrategy from the given Configuration.
createFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
Creates a NoRestartStrategyFactory instance.
createFailoverRegion(ExecutionGraph, List<ExecutionVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
createFileSystemStateStorage(Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Creates a FileSystemStateStorageHelper instance.
createForDeserializedState() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
 
createForDeserializedState() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformFactory
 
createForDeserializedState() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformFactory
 
createForDeserializedState() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
 
createForSerializedState() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
 
createForSerializedState() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
 
createFrom(Configuration) - 类 中的静态方法org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
 
createFrom(ExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
Create a ArchivedExecutionGraph from the given ExecutionGraph.
createFrom(AccessExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobResult
Creates the JobResult from the given AccessExecutionGraph which must be in a globally terminal state.
createFromConfig(Configuration, ClassLoader) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
createFromConfig(Configuration, ClassLoader) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
 
createFromConfig(Configuration, ClassLoader) - 接口 中的方法org.apache.flink.runtime.state.StateBackendFactory
Creates the state backend, optionally using the given configuration.
createGateway(CompletableFuture<Tuple2<String, UUID>>) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
 
createGateway(CompletableFuture<Tuple2<String, UUID>>) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
 
createHaServices(Configuration, Executor) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createHAServices(Configuration, Executor) - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesFactory
Creates an HighAvailabilityServices instance.
createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which does not actively send heartbeats.
createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
createHeartbeatServices(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createHighAvailabilityServices(Configuration, Executor, HighAvailabilityServicesUtils.AddressResolution) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
createHighAvailabilityServices(Configuration, Executor) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
createHistoryServerArchivist(Configuration, JsonArchivist) - 接口 中的静态方法org.apache.flink.runtime.dispatcher.HistoryServerArchivist
 
createInputChannelDeploymentDescriptor(Execution) - 类 中的方法org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a channel deployment descriptor by completing the partition location.
createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
createInstance() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
createInstance(Object...) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
createInstance() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
createInternalClientSSLEngineFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates a SSLEngineFactory to be used by internal communication client endpoints.
createInternalServerSSLEngineFactory(Configuration) - 类 中的静态方法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>) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateFactory
Creates and returns a new InternalKvState.
createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateFactory
Creates and returns a new InternalKvState.
createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - 枚举 中的方法org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
 
createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.dispatcher.JobManagerRunnerFactory
 
createJobMasterService(JobGraph, OnCompletionActions, ClassLoader) - 类 中的方法org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory
 
createJobMasterService(JobGraph, OnCompletionActions, ClassLoader) - 接口 中的方法org.apache.flink.runtime.jobmaster.factories.JobMasterServiceFactory
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.AbstractStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - 接口 中的方法org.apache.flink.runtime.state.StateBackend
Creates a new AbstractKeyedStateBackend that is responsible for holding keyed state and checkpointing it.
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
createKeyGroupPartitionReader(KeyGroupPartitioner.ElementReaderFunction<T>, KeyGroupPartitioner.KeyGroupElementsConsumer<T>) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupPartitioner
 
createKeyGroupPartitions(int, int) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Groups the available set of key groups into key group partitions.
createKvStateClientProxy(InetAddress, Iterator<Integer>, int, int, KvStateRequestStats) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.query.QueryableStateUtils
Initializes the server responsible for sending the requested internal state to the client proxy.
createKvStateTaskRegistry(JobID, JobVertexID) - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
createLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderElectionService(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderElectionService(CuratorFramework, Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderRetrievalService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderRetrievalService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
createLeaderRetrievalService(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService from the given configuration.
createLeaderRetrievalService(Configuration, boolean, String) - 类 中的静态方法org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService form the given configuration and the JobManager name.
createLeaderRetrievalService(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
createLeaderRetrievalService(CuratorFramework, Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
createLocal() - 类 中的静态方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createLocalRecoveryConfig() - 接口 中的方法org.apache.flink.runtime.state.TaskStateManager
Returns the configuration for local recovery, i.e. the base directories for all file-based local state of the owning subtask and the general mode for local recovery.
createLocalRecoveryConfig() - 类 中的方法org.apache.flink.runtime.state.TaskStateManagerImpl
 
createLogicalScope(CharacterFilter, char) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
createLogicalScope(CharacterFilter, char) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
 
createMetadataOutputStream() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorageLocation
Creates the output stream to persist the checkpoint metadata to.
createMetadataOutputStream() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
createMetadataOutputStream() - 类 中的方法org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
 
createMetadataOutputStream() - 类 中的方法org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
 
createMetricRegistry(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createMetricRegistry(Configuration) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
Factory method to create the metric registry for the mini cluster.
createModule(SecurityConfiguration) - 类 中的方法org.apache.flink.runtime.security.modules.HadoopModuleFactory
 
createModule(SecurityConfiguration) - 类 中的方法org.apache.flink.runtime.security.modules.JaasModuleFactory
 
createModule(SecurityConfiguration) - 接口 中的方法org.apache.flink.runtime.security.modules.SecurityModuleFactory
Creates and returns a SecurityModule.
createModule(SecurityConfiguration) - 类 中的方法org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
 
createNettySSLHandler() - 类 中的方法org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
 
createNettySSLHandler(String, int) - 类 中的方法org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
 
createNoTransform() - 接口 中的静态方法org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
 
createOperationKey(HandlerRequest<B, M>) - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
 
createOperationKey(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
 
createOperationKey(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
 
createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.AbstractStateBackend
 
createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - 接口 中的方法org.apache.flink.runtime.state.StateBackend
Creates a new OperatorStateBackend that can be used for storing operator state.
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
 
createPartitionRequestClient(ConnectionID) - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
Creates a PartitionRequestClient instance for the given ConnectionID.
createPartitionRequestClient(ConnectionID) - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
createPartitionRequestClient(ConnectionID) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
createPartitions(int, int) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Creates the metric query service scope for this group.
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
createRandomName(String) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Creates a random name of the form prefix_X, where X is an increasing number.
createReadView(BufferAvailabilityListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
createRecordWriter(ResultPartitionWriter, ChannelSelector, long, String) - 类 中的静态方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
createRecordWriter(ResultPartitionWriter, ChannelSelector, String) - 类 中的静态方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
createRemote(ConnectionID) - 类 中的静态方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
 
createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - 枚举 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
 
createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.NoOrFixedIfCheckpointingEnabledRestartStrategyFactory
 
createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Factory method to create a restart strategy
createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given RestartStrategies.RestartStrategyConfiguration.
createRestartStrategyFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given Configuration.
createRestClientSSLContext(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates an SSL context for clients against the external REST endpoint.
createRestClientSSLEngineFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates a SSLHandlerFactory to be used by the REST Clients.
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 枚举 中的方法org.apache.flink.runtime.rest.JobRestEndpointFactory
 
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.rest.RestEndpointFactory
 
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 枚举 中的方法org.apache.flink.runtime.rest.SessionRestEndpointFactory
 
createRestServerSSLContext(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates an SSL context for the external REST endpoint server.
createRestServerSSLEngineFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates a SSLHandlerFactory to be used by the REST Servers.
createResult(CommandLine) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
 
createResult(CommandLine) - 类 中的方法org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
 
createResult(CommandLine) - 接口 中的方法org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
Create the result of the command line argument parsing.
createRpcService() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster.CommonRpcServiceFactory
 
createRpcService(AkkaRpcServiceConfiguration, boolean, String) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
Factory method to instantiate the RPC service.
createRpcService() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster.DedicatedRpcServiceFactory
 
createRpcService() - 接口 中的方法org.apache.flink.runtime.minicluster.MiniCluster.RpcServiceFactory
 
createRpcService(String, String, Configuration) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Utility method to create RPC service from configuration and hostname, port.
createRpcService(String, int, Configuration) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Utility method to create RPC service from configuration and hostname, port.
createRpcService(Configuration, HighAvailabilityServices) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
Create a RPC service for the task manager.
createRuntimeContext(MetricGroup) - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createRuntimeContext(MetricGroup) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
createRuntimeContext() - 类 中的方法org.apache.flink.runtime.operators.DataSinkTask
 
createRuntimeContext() - 类 中的方法org.apache.flink.runtime.operators.DataSourceTask
 
createSavepointLocation(FileSystem, Path) - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
createSavepointLocation(FileSystem, Path) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
createSavepointLocation(FileSystem, Path) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
createScheduler(SlotPool) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DefaultSchedulerFactory
 
createScheduler(SlotPool) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerFactory
Creates a new scheduler instance that uses the given SlotPool to allocate slots.
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
createSerializerInstance(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
createServerSSLEngineFactory() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
createSharedCount(String, int) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedCount to store a shared count between multiple instances.
createSharedStateRegistryKeyFromFileName(StateHandleID) - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
Create a unique key to register one of our shared state handles.
createSharedValue(String, byte[]) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedValue to store a shared value between multiple instances.
createSimpleStream(CheckpointedStateScope, CheckpointStreamFactory) - 接口 中的静态方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
createSlotPool(JobID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
createSlotPool(JobID) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolFactory
 
createSlotReport(ResourceID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
createSlotsPerWorker(int) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
createSnapshot() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new snapshot of the available stats.
createSnapshot() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
createSolutionSetUpdateOutputCollector(Collector<OT>) - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
Creates a new solution set update output collector.
createSSLClientSocketFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Creates a factory for SSL Client Sockets from the given configuration.
createSSLServerSocketFactory(Configuration) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.state.ttl.TtlStateFactory
 
createSubmittedJobGraphs(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
createSubpartitionView(int, BufferAvailabilityListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the requested subpartition.
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
Returns the requested intermediate result partition input view.
createTaskOwnedStateStream() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Opens a stream to persist checkpoint state data that is owned strictly by tasks and not attached to the life cycle of a specific checkpoint.
createTaskOwnedStateStream() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
createTaskOwnedStateStream() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
createTaskRegistry(JobID, JobVertexID) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Creates a TaskKvStateRegistry facade for the Task identified by the given JobID and JobVertexID instance.
createTerminationFutureOverAllConnectedVertexes() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.filecache.FileCache
If the file doesn't exists locally, retrieve the file from the blob-service.
createUnknown() - 类 中的静态方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createUnregisteredJobManagerJobMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredJobManagerMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredOperatorMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredTaskManagerJobMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredTaskManagerMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredTaskMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createWorksetUpdateOutputCollector(Collector<OT>) - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
createWorksetUpdateOutputCollector() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createZooKeeperStateHandleStore(CuratorFramework, String, RetrievableStateStorageHelper<T>) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Creates an instance of ZooKeeperStateHandleStore.
createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperStateHandleStore instance with the provided arguments.
CrossDriver<T1,T2,OT> - org.apache.flink.runtime.operators中的类
Cross task which is executed by a Task Manager.
CrossDriver() - 类 的构造器org.apache.flink.runtime.operators.CrossDriver
 
crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - 类 中的方法org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
CURRENT_JOB_IDS_REST_PATH - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
CURRENT_STATE_META_INFO_SNAPSHOT_VERSION - 类 中的静态变量org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
Current version for the serialization format of StateMetaInfoSnapshotReadersWriters
currentEnumerator - 类 中的变量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() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
currentlyRegisteredTaskManagers() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
currentNamespace - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapState
The current namespace, which the access methods will refer to.
currentRecursionDepth - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The recursion depth of the partition that is currently processed.
currentSchemaSerializer() - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
Gets the serializer that recognizes the current serialization schema of the state.
currentTimestamp() - 接口 中的方法org.apache.flink.runtime.state.ttl.TtlTimeProvider
 

D

DamBehavior - org.apache.flink.runtime.operators中的枚举
Enumeration for the different dam behaviors of an algorithm or a driver strategy.
damOnInput(int) - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
dams() - 枚举 中的方法org.apache.flink.runtime.operators.util.LocalStrategy
 
DashboardConfigHandler - org.apache.flink.runtime.rest.handler.cluster中的类
Handler which returns the dashboard configuration.
DashboardConfigHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, DashboardConfiguration, EmptyMessageParameters>, long) - 类 的构造器org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
 
DashboardConfiguration - org.apache.flink.runtime.rest.messages中的类
Response of the DashboardConfigHandler containing general configuration values such as the time zone and the refresh interval.
DashboardConfiguration(long, String, int, String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
DashboardConfigurationHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the DashboardConfigHandler.
DataExchangeMode - org.apache.flink.runtime.io.network中的枚举
Defines how the data exchange between two specific operators happens.
dataPort() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the port instance's task manager expects to receive transfer envelopes on.
DataSinkTask<IT> - org.apache.flink.runtime.operators中的类
DataSinkTask which is executed by a task manager.
DataSinkTask(Environment) - 类 的构造器org.apache.flink.runtime.operators.DataSinkTask
Create an Invokable task and set its environment.
DataSourceTask<OT> - org.apache.flink.runtime.operators中的类
DataSourceTask which is executed by a task manager.
DataSourceTask(Environment) - 类 的构造器org.apache.flink.runtime.operators.DataSourceTask
Create an Invokable task and set its environment.
date() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
deallocate() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
Decline(String) - 类 的构造器org.apache.flink.runtime.registration.RegistrationResponse.Decline
Creates a new rejection message.
declineCheckpoint(DeclineCheckpoint) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
declineCheckpoint(long, Throwable) - 接口 中的方法org.apache.flink.runtime.execution.Environment
Declines a checkpoint.
declineCheckpoint(DeclineCheckpoint) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
DeclineCheckpoint - org.apache.flink.runtime.messages.checkpoint中的类
This message is sent from the TaskExecutor to the JobMaster to tell the checkpoint coordinator that a checkpoint request could not be heeded.
DeclineCheckpoint(JobID, ExecutionAttemptID, long) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
DeclineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - 接口 中的方法org.apache.flink.runtime.taskmanager.CheckpointResponder
Declines the given checkpoint.
declineCheckpoint(long, Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - 类 中的方法org.apache.flink.runtime.net.RedirectingSslHandler
 
decode(ChannelHandlerContext, HttpObject, List<Object>) - 类 中的方法org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
 
decodedPath() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Returns the decoded request path.
decodePathFromReference(CheckpointStorageLocationReference) - 类 中的静态方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Decodes the given reference into a path.
decorate(Object) - 类 中的方法org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
 
decorate(Object) - 接口 中的方法org.apache.flink.runtime.messages.MessageDecorator
Decorates a message
decorateMessage(Object) - 类 中的方法org.apache.flink.runtime.akka.FlinkUntypedActor
This method should be called for every outgoing message.
decorateWithCompression(NonClosingOutpusStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
decorateWithCompression(OutputStream) - 类 中的方法org.apache.flink.runtime.state.StreamCompressionDecorator
Decorates the stream by wrapping it into a stream that applies a compression.
decorateWithCompression(InputStream) - 类 中的方法org.apache.flink.runtime.state.StreamCompressionDecorator
IMPORTANT: For streams returned by this method, InputStream.close() is not propagated to the inner stream.
decorateWithCompression(NonClosingOutpusStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.StreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.StreamCompressionDecorator
 
decorateWithCompression(NonClosingOutpusStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - 类 中的方法org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
decreaseBuffersInBacklog(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Decreases the number of non-event buffers by one after fetching a non-event buffer from this subpartition (for access by the subpartition views).
decreaseBuffersInBacklogUnsafe(boolean) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
decrement() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Decrements the reference count and returns whether the reference counter entered the disposed state.
decrementReference(BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
decrementReferenceIfHeld(BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
deepCopy() - 接口 中的方法org.apache.flink.runtime.state.BackendWritableBroadcastState
 
deepCopy() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
deepCopy() - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
deepCopy() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
Creates a deep copy of the itself.
deepCopy() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
Creates a deep copy of the itself.
deepCopy() - 类 中的方法org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
DEFAULT - 接口 中的静态变量org.apache.flink.runtime.state.ttl.TtlTimeProvider
 
DEFAULT_CAPACITY - 类 中的静态变量org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Default capacity for a CopyOnWriteStateTable.
DEFAULT_FACTORY - 类 中的静态变量org.apache.flink.runtime.state.SharedStateRegistry
A singleton object for the default implementation of a SharedStateRegistryFactory
DEFAULT_JOB_ID - 接口 中的静态变量org.apache.flink.runtime.highavailability.HighAvailabilityServices
This JobID should be used to identify the old JobManager when using the HighAvailabilityServices.
DEFAULT_LEADER_ID - 接口 中的静态变量org.apache.flink.runtime.highavailability.HighAvailabilityServices
This UUID should be used when no proper leader election happens, but a simple pre-configured leader is used.
DEFAULT_LOWER_BOUND_MAX_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.state.KeyGroupRangeAssignment
The default lower bound for max parallelism if nothing was configured by the user.
DEFAULT_MAX_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.state.memory.MemoryStateBackend
The default maximal size that the snapshotted memory state may have (5 MiBytes).
DEFAULT_OPERATOR_STATE_NAME - 类 中的静态变量org.apache.flink.runtime.state.DefaultOperatorStateBackend
The default namespace for state in cases where no state name is provided
DEFAULT_PAGE_SIZE - 类 中的静态变量org.apache.flink.runtime.memory.MemoryManager
The default memory page size.
DEFAULT_WRITE_BUFFER_SIZE - 类 中的静态变量org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
Default size for the write buffer.
DEFAULT_ZOOKEEPER_CLIENT_PORT - 类 中的静态变量org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default client port.
DEFAULT_ZOOKEEPER_INIT_LIMIT - 类 中的静态变量org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default init limit.
DEFAULT_ZOOKEEPER_LEADER_PORT - 类 中的静态变量org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default leader port.
DEFAULT_ZOOKEEPER_PEER_PORT - 类 中的静态变量org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default peer port.
DEFAULT_ZOOKEEPER_SYNC_LIMIT - 类 中的静态变量org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default sync limit.
DefaultBroadcastVariableInitializer<T> - org.apache.flink.runtime.broadcast中的类
The default BroadcastVariableInitializer implementation that initializes the broadcast variable into a list.
defaultConfiguration() - 类 中的静态方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
defaultConfiguration() - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
DefaultInMemorySorterFactory<T> - org.apache.flink.runtime.operators.sort中的类
Default factory for InMemorySorter.
DefaultJobManagerJobMetricGroupFactory - org.apache.flink.runtime.jobmaster.factories中的类
Default implementation of JobManagerJobMetricGroupFactory which creates for a given JobGraph a JobManagerJobMetricGroup.
DefaultJobManagerJobMetricGroupFactory(JobManagerMetricGroup) - 类 的构造器org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
 
DefaultJobManagerRunnerFactory - org.apache.flink.runtime.dispatcher中的枚举
Singleton default factory for JobManagerRunner.
DefaultJobMasterServiceFactory - org.apache.flink.runtime.jobmaster.factories中的类
Default implementation of the JobMasterServiceFactory.
DefaultJobMasterServiceFactory(JobMasterConfiguration, SlotPoolFactory, SchedulerFactory, RpcService, HighAvailabilityServices, JobManagerSharedServices, HeartbeatServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory
 
DefaultKeyedStateStore - org.apache.flink.runtime.state中的类
Default implementation of KeyedStateStore that currently forwards state registration to a RuntimeContext.
DefaultKeyedStateStore(KeyedStateBackend<?>, ExecutionConfig) - 类 的构造器org.apache.flink.runtime.state.DefaultKeyedStateStore
 
defaultMetricRegistryConfiguration() - 类 中的静态方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
DefaultOperatorStateBackend - org.apache.flink.runtime.state中的类
Default implementation of OperatorStateStore that provides the ability to make snapshots.
DefaultOperatorStateBackend(ExecutionConfig, CloseableRegistry, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, AbstractSnapshotStrategy<OperatorStateHandle>) - 类 的构造器org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
DefaultOperatorStateBackendBuilder - org.apache.flink.runtime.state中的类
Builder class for DefaultOperatorStateBackend which handles all necessary initializations and clean ups.
DefaultOperatorStateBackendBuilder(ClassLoader, ExecutionConfig, boolean, Collection<OperatorStateHandle>, CloseableRegistry) - 类 的构造器org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
 
DefaultQuarantineHandler - org.apache.flink.runtime.akka中的类
Default quarantine handler which logs the quarantining events, then shuts down the given actor system by sending Kill to all actors and then shutting the JVM down with the given exit code.
DefaultQuarantineHandler(Time, int, Logger) - 类 的构造器org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
DefaultSchedulerFactory - org.apache.flink.runtime.jobmaster.slotpool中的类
Default implementation of a SchedulerFactory.
DefaultSchedulerFactory(SlotSelectionStrategy) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.DefaultSchedulerFactory
 
DefaultSlotPoolFactory - org.apache.flink.runtime.jobmaster.slotpool中的类
Default slot pool factory.
DefaultSlotPoolFactory(Clock, Time, Time) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
delegate - 类 中的变量org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
delete(JobID, BlobKey) - 接口 中的方法org.apache.flink.runtime.blob.BlobStore
Tries to delete a blob from storage.
delete(JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
delete(JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
deleteAll(JobID) - 接口 中的方法org.apache.flink.runtime.blob.BlobStore
Tries to delete all blobs for the given job from storage.
deleteAll(JobID) - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
deleteAll(JobID) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
deleteChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
deleteChannel() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Deletes the file underlying this I/O channel.
deleteChannel(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Deletes the file underlying the given channel.
deleteChildren() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Recursively deletes all children.
deleteFromCache(TransientBlobKey) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Deletes the (job-unrelated) file associated with the blob key in the local storage of the blob server.
deleteFromCache(JobID, TransientBlobKey) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Deletes the file associated with the blob key in the local storage of the blob server.
deleteFromCache(TransientBlobKey) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
deleteFromCache(JobID, TransientBlobKey) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
deleteFromCache(TransientBlobKey) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Deletes the (job-unrelated) file associated with the provided blob key from the local cache.
deleteFromCache(JobID, TransientBlobKey) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Deletes the file associated with the provided job ID and blob key from the local cache.
DependencyVisitor - org.apache.flink.runtime.util中的类
This class tracks class dependency with ASM visitors.
DependencyVisitor(int) - 类 的构造器org.apache.flink.runtime.util.DependencyVisitor
 
DependencyVisitor.AnnotationVisitorImpl - org.apache.flink.runtime.util中的类
 
DependencyVisitor.FieldVisitorImpl - org.apache.flink.runtime.util中的类
 
DependencyVisitor.MethodVisitorImpl - org.apache.flink.runtime.util中的类
 
DependencyVisitor.SignatureVisitorImpl - org.apache.flink.runtime.util中的类
 
deploy() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Deploys the execution to the previously assigned resource.
deployToSlot(LogicalSlot) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
deprecated() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
deregisterApplication(ApplicationStatus, String) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Cleanup application and shut down cluster.
deregisterApplication(ApplicationStatus, String) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Deregister Flink from the underlying resource management system.
deregisterApplicationAndClose(ApplicationStatus, String) - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
Deregister the Flink application from the resource management system by signalling the ResourceManager.
deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
description - 类 中的变量org.apache.flink.runtime.state.AbstractSnapshotStrategy
Descriptive name of the snapshot strategy that will appear in the log outputs and AbstractSnapshotStrategy.toString().
DescriptiveStatisticsHistogram - org.apache.flink.runtime.metrics中的类
The DescriptiveStatisticsHistogram use a DescriptiveStatistics DescriptiveStatistics as a Flink Histogram.
DescriptiveStatisticsHistogram(int) - 类 的构造器org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
DescriptiveStatisticsHistogramStatistics - org.apache.flink.runtime.metrics中的类
DescriptiveStatistics histogram statistics implementation returned by DescriptiveStatisticsHistogram.
DescriptiveStatisticsHistogramStatistics(DescriptiveStatistics) - 类 的构造器org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
DeserializationDelegate<T> - org.apache.flink.runtime.plugable中的接口
The deserialization delegate is used during deserialization to read an arbitrary element as if it implements IOReadableWritable, with the help of a type serializer.
deserialize(DataInputStream, ClassLoader) - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Deserializes a savepoint from an input stream.
deserialize(DataInputStream, ClassLoader) - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserialize(DataInputStream, ClassLoader) - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsDeserializer
 
deserialize(MetricDumpSerialization.MetricSerializationResult) - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
De-serializes metrics from the given byte array and returns them as a list of MetricDump.
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Deserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Deserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.Deserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Deserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobIDDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobResultDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobVertexIDDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
 
deserialize(JsonParser, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(ArrayList<T>, DataInputView) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(DataInputView) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserialize(VoidNamespace, DataInputView) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserializeKey(String, DeserializationContext) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobVertexIDKeyDeserializer
 
deserializeKeyedStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeKeyedStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
deserializeOperatorStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeOperatorStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
Deserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Deserializer
 
Deserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Deserializer
 
Deserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.JobConfigInfo.Deserializer
 
Deserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Deserializer
 
deserializeStreamStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeStreamStateHandle(DataInputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
deserializeUserAccumulators(ClassLoader) - 类 中的方法org.apache.flink.runtime.accumulators.AccumulatorSnapshot
Gets the user-defined accumulators values.
dest - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
dest - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
destroy() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
destroyAllBufferPools() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
Destroys all buffer pools that allocate their buffers from this buffer pool (created via NetworkBufferPool.createBufferPool(int, int)).
destroyBufferPool(BufferPool) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
Destroy callback for updating factory book keeping.
destroyBufferPool(BufferPool) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
destroyBufferPool() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
directExecutionContext() - 类 中的静态方法org.apache.flink.runtime.concurrent.Executors
Return a direct execution context.
directExecutor() - 类 中的静态方法org.apache.flink.runtime.concurrent.Executors
Return a direct executor.
directory - 类 中的变量org.apache.flink.runtime.state.SnapshotDirectory
This path describes the underlying directory for the snapshot.
DirectoryKeyedStateHandle - org.apache.flink.runtime.state中的类
This class is a keyed state handle based on a directory.
DirectoryKeyedStateHandle(DirectoryStateHandle, KeyGroupRange) - 类 的构造器org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
DirectoryStateHandle - org.apache.flink.runtime.state中的类
This state handle represents a directory.
DirectoryStateHandle(Path) - 类 的构造器org.apache.flink.runtime.state.DirectoryStateHandle
 
disabled() - 类 中的静态方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Gets the configuration describing the queryable state as deactivated.
discardOnFailedStoring() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnShutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnSubsume() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
discardState() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
discardState() - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
Discard the state by deleting the file that stores the state.
discardState() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
discardState() - 类 中的方法org.apache.flink.runtime.state.SnapshotResult
 
discardState() - 接口 中的方法org.apache.flink.runtime.state.StateObject
Discards the state referred to and solemnly owned by this handle, to free up resources in the persistent storage.
discardStateFuture(RunnableFuture<? extends StateObject>) - 类 中的静态方法org.apache.flink.runtime.state.StateUtil
Discards the given state future by first trying to cancel it.
disconnectJobManager(JobID, Exception) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
disconnectJobManager(JobID, Exception) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Disconnects a JobManager specified by the given resourceID from the ResourceManager.
disconnectJobManager(JobID, Exception) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
disconnectJobManager(JobID, Exception) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Disconnects the given JobManager from the TaskManager.
disconnectResourceManager(ResourceManagerId, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
disconnectResourceManager(ResourceManagerId, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Disconnects the resource manager from the job manager because of the given cause.
disconnectResourceManager() - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Disconnects the slot pool from its current Resource Manager.
disconnectResourceManager() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
disconnectResourceManager(Exception) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
disconnectResourceManager(Exception) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Disconnects the ResourceManager from the TaskManager.
disconnectTaskManager(ResourceID, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
disconnectTaskManager(ResourceID, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Disconnects the given TaskExecutor from the JobMaster.
disconnectTaskManager(ResourceID, Exception) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
disconnectTaskManager(ResourceID, Exception) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Disconnects a TaskManager specified by the given resourceID from the ResourceManager.
Dispatcher - org.apache.flink.runtime.dispatcher中的类
Base class for the Dispatcher component.
Dispatcher(RpcService, String, Configuration, HighAvailabilityServices, SubmittedJobGraphStore, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, JobManagerRunnerFactory, FatalErrorHandler, HistoryServerArchivist) - 类 的构造器org.apache.flink.runtime.dispatcher.Dispatcher
 
DISPATCHER_NAME - 类 中的静态变量org.apache.flink.runtime.dispatcher.Dispatcher
 
DispatcherException - org.apache.flink.runtime.dispatcher中的异常错误
Base class for Dispatcher related exceptions.
DispatcherException(String) - 异常错误 的构造器org.apache.flink.runtime.dispatcher.DispatcherException
 
DispatcherException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.dispatcher.DispatcherException
 
DispatcherException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.dispatcher.DispatcherException
 
DispatcherFactory<T extends Dispatcher> - org.apache.flink.runtime.dispatcher中的接口
Dispatcher factory interface.
DispatcherGateway - org.apache.flink.runtime.dispatcher中的接口
Gateway for the Dispatcher component.
DispatcherId - org.apache.flink.runtime.dispatcher中的类
Fencing token of the Dispatcher.
DispatcherResourceManagerComponent<T extends Dispatcher> - org.apache.flink.runtime.entrypoint.component中的类
Component which starts a Dispatcher, ResourceManager and WebMonitorEndpoint in the same process.
DispatcherResourceManagerComponentFactory<T extends Dispatcher> - org.apache.flink.runtime.entrypoint.component中的接口
DispatcherRestEndpoint - org.apache.flink.runtime.dispatcher中的类
REST endpoint for the Dispatcher component.
DispatcherRestEndpoint(RestServerEndpointConfiguration, GatewayRetriever<DispatcherGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
 
DispatcherThreadFactory - org.apache.flink.runtime.taskmanager中的类
Thread factory that creates threads with a given name, associates them with a given thread group, and set them to daemon mode.
DispatcherThreadFactory(ThreadGroup, String) - 类 的构造器org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
Creates a new thread factory.
DispatcherThreadFactory(ThreadGroup, String, ClassLoader) - 类 的构造器org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
Creates a new thread factory.
dispose() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
dispose() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
dispose() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
dispose() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Disposes the sorter.
dispose() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
dispose() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
Closes the state backend, releasing all internal resources, but does not delete any persistent checkpoint data.
dispose() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
dispose() - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
 
dispose() - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
dispose() - 接口 中的方法org.apache.flink.runtime.state.OperatorStateBackend
 
dispose() - 接口 中的方法org.apache.flink.runtime.state.OwnedTaskLocalStateStore
Disposes the task local state store.
dispose() - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
Disposes the state of all local snapshots managed by this object.
disposeIfNotUsed() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
disposeOnFailure() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorageLocation
Disposes the checkpoint location in case the checkpoint has failed.
disposeOnFailure() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
disposeOnFailure() - 类 中的方法org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
 
disposeOnFailure() - 类 中的方法org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
 
disposeSavepoint(String, StateBackend, ClassLoader) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
disposeSavepoint(String, Configuration, ClassLoader, Logger) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
disposeSavepoint(String, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
disposeSavepoint(String) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
disposeSavepoint(String, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Dispose the given savepoint.
disposeSortBuffers(boolean) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Releases the memory that is registered for in-memory sorted run generation.
disposeStorageLocation() - 接口 中的方法org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
Disposes the storage location.
disposeStorageLocation() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
 
DistributedCacheFile(String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
DistributedRuntimeUDFContext - org.apache.flink.runtime.operators.util中的类
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
DistributedRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, MetricGroup) - 类 的构造器org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
DistributionPattern - org.apache.flink.runtime.jobgraph中的枚举
A distribution pattern determines, which sub tasks of a producing task are connected to which consuming sub tasks.
done() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
 
DoneFuture<T> - org.apache.flink.runtime.state中的类
A Future that is always done and will just yield the object that was given at creation time.
DoneFuture(T) - 类 的构造器org.apache.flink.runtime.state.DoneFuture
 
DownTimeGauge - org.apache.flink.runtime.executiongraph.metrics中的类
A gauge that returns (in milliseconds) how long a job has not been not running any more, in case it is in a failing/recovering situation.
DownTimeGauge(ExecutionGraph) - 类 的构造器org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
driver - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The driver that invokes the user code (the stub implementation).
Driver<S extends org.apache.flink.api.common.functions.Function,OT> - org.apache.flink.runtime.operators中的接口
The interface to be implemented by all drivers that run alone (or as the primary driver) in a task.
DriverStrategy - org.apache.flink.runtime.operators中的枚举
Enumeration of all available operator strategies.
DualKeyMap<A,B,V> - org.apache.flink.runtime.jobmaster.slotpool中的类
Map which stores values under two different indices.
DualKeyMap(int) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
DummyComponentMainThreadExecutor(String) - 类 的构造器org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
duplicate() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
Creates a deep copy of the current KvStateInfo by duplicating all the included serializers.
duplicate() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
DuplicatingCheckpointOutputStream - org.apache.flink.runtime.state中的类
A CheckpointStateOutputStream that wraps a primary and a secondary CheckpointStateOutputStream and duplicates all writes into both streams.
DuplicatingCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream) - 类 的构造器org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
DuplicatingCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream, int) - 类 的构造器org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
DYNAMIC_PROPERTY_OPTION - 类 中的静态变量org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
 
DynamicConfiguration - org.apache.flink.runtime.security中的类
A dynamic JAAS configuration.
DynamicConfiguration(Configuration) - 类 的构造器org.apache.flink.runtime.security.DynamicConfiguration
Create a dynamic configuration.

E

elementKeyGroups - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
This is a helper array that caches the key-group for each element, so we do not have to compute them twice.
elementPriorityComparator - 类 中的变量org.apache.flink.runtime.state.heap.HeapPriorityQueue
Comparator for the priority of contained elements.
elementWriterFunction - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
Function to write an element to a DataOutputView.
EmbeddedHaServices - org.apache.flink.runtime.highavailability.nonha.embedded中的类
An implementation of the HighAvailabilityServices for the non-high-availability case where all participants (ResourceManager, JobManagers, TaskManagers) run in the same process.
EmbeddedHaServices(Executor) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
EmbeddedLeaderService - org.apache.flink.runtime.highavailability.nonha.embedded中的类
A simple leader election service, which selects a leader among contenders and notifies listeners.
EmbeddedLeaderService(Executor) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
emit(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
 
emit(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
emit() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Emits all elements currently held by the table to the collector.
emitAndReset() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Emits all elements currently held by the table to the collector, and resets the table.
empty() - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
empty() - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceOverview
 
EMPTY - 类 中的静态变量org.apache.flink.runtime.rest.handler.FileUploads
 
empty() - 类 中的静态方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
empty() - 类 中的静态方法org.apache.flink.runtime.state.SnapshotResult
 
EMPTY - 类 中的静态变量org.apache.flink.runtime.util.IntArrayList
 
empty() - 接口 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorExtension
 
EMPTY_KEY_GROUP_RANGE - 类 中的静态变量org.apache.flink.runtime.state.KeyGroupRange
The empty key-group
EmptyIterator<E> - org.apache.flink.runtime.util中的类
An empty iterator that never returns anything.
EmptyIterator() - 类 的构造器org.apache.flink.runtime.util.EmptyIterator
 
EmptyMessageParameters - org.apache.flink.runtime.rest.messages中的类
MessageParameters implementation which has no parameters.
EmptyMutableObjectIterator<E> - org.apache.flink.runtime.util中的类
An empty mutable object iterator that never returns anything.
EmptyMutableObjectIterator() - 类 的构造器org.apache.flink.runtime.util.EmptyMutableObjectIterator
 
emptyNotRestored() - 类 中的静态方法org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
Returns an empty PrioritizedOperatorSubtaskState singleton for an empty, not-restored operator state.
EmptyRequestBody - org.apache.flink.runtime.rest.messages中的类
Request which do not have a request payload.
EmptyResponseBody - org.apache.flink.runtime.rest.messages中的类
Empty ResponseBody implementation.
enableCheckpointing(long, long, long, int, CheckpointRetentionPolicy, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<MasterTriggerRestoreHook<?>>, CheckpointIDCounter, CompletedCheckpointStore, StateBackend, CheckpointStatsTracker) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
encodePathAsReference(Path) - 类 中的静态方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Encodes the given path as a reference in bytes.
ENCODING - 类 中的静态变量org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
endMarker() - 类 中的静态方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for the end of data.
EndOfPartitionEvent - org.apache.flink.runtime.io.network.api中的类
This event marks a subpartition as fully consumed.
EndOfSuperstepEvent - org.apache.flink.runtime.io.network.api中的类
Marks the end of a superstep of one particular iteration superstep.
ensureWritable(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
enterMainThread() - 类 中的方法org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
entries() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
EntryIterator() - 类 的构造器org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
entryName - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
EntrypointClusterConfiguration - org.apache.flink.runtime.entrypoint中的类
Basic ClusterConfiguration for entry points.
EntrypointClusterConfiguration(String, Properties, String[], String, int) - 类 的构造器org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
 
EntrypointClusterConfigurationParserFactory - org.apache.flink.runtime.entrypoint中的类
Parser factory for EntrypointClusterConfiguration.
EntrypointClusterConfigurationParserFactory() - 类 的构造器org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
 
Enumerator(File[], Random) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
 
envelopeSelfMessage(Object) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
Environment - org.apache.flink.runtime.execution中的接口
The Environment gives the code executed in a task access to the task's properties (such as name, parallelism), the configurations, the data stream readers and writers, as well as the various components that are provided by the TaskManager, such as memory manager, I/O manager, ...
EnvironmentInformation - org.apache.flink.runtime.util中的类
Utility class that gives access to the execution environment of the JVM, like the executing user, startup options, or the JVM version.
EnvironmentInformation.RevisionInformation - org.apache.flink.runtime.util中的类
Revision information encapsulates information about the source code revision of the Flink code.
equals(Object) - 类 中的方法org.apache.flink.runtime.blob.BlobKey
 
equals(Object) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointOptions
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
equals(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
equals(Object) - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
equals(Object) - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
 
equals(Object) - 类 中的方法org.apache.flink.runtime.instance.Slot
Slots must always compare on referential equality.
equals(Object) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
equals(Object) - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
equals(Object) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
equals(Object) - 异常错误 中的方法org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
equals(Object) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
equals(Object) - 类 中的方法org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
equals(Object) - 类 中的方法org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.Acknowledge
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
equals(Object) - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.handler.async.OperationKey
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
This method is should only be called in tests!
equals(Object) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.VoidNamespace
 
equals(Object) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
equals(Object) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
equals(Object) - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
 
equals(Object) - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
equals(Object) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
 
equals(Object) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
equals(Object) - 类 中的方法org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
 
equals(Object) - 类 中的方法org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
error() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
ErrorInfo - org.apache.flink.runtime.executiongraph中的类
Simple container to hold an exception and the corresponding timestamp.
ErrorInfo(Throwable, long) - 类 的构造器org.apache.flink.runtime.executiongraph.ErrorInfo
 
ErrorResponseBody - org.apache.flink.runtime.rest.messages中的类
Generic response body for communicating errors on the server.
ErrorResponseBody(String) - 类 的构造器org.apache.flink.runtime.rest.messages.ErrorResponseBody
 
ErrorResponseBody(List<String>) - 类 的构造器org.apache.flink.runtime.rest.messages.ErrorResponseBody
 
errors - 类 中的变量org.apache.flink.runtime.rest.messages.ErrorResponseBody
 
estimateFalsePositiveProbability(long, int) - 类 中的静态方法org.apache.flink.runtime.operators.util.BloomFilter
Compute the false positive probability based on given input entries and bits size.
EventListener<T> - org.apache.flink.runtime.util.event中的接口
 
EventSerializer - org.apache.flink.runtime.io.network.api.serialization中的类
Utility class to serialize and deserialize task events.
EventSerializer() - 类 的构造器org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
eventualOutputs - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The output writers for the data that this task forwards to the next task.
EvictingBoundedList<T> - org.apache.flink.runtime.util中的类
This class implements a list (array based) that is physically bounded in maximum size, but can virtually grow beyond the bounded size.
EvictingBoundedList(int) - 类 的构造器org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(EvictingBoundedList<T>) - 类 的构造器org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(int, T) - 类 的构造器org.apache.flink.runtime.util.EvictingBoundedList
 
exception - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
An exception that was encountered by the asynchronous request handling thread.
exceptionalOperationResultResponse(Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
Create an exceptional operation result from the given Throwable.
exceptionalOperationResultResponse(Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
 
exceptionalOperationResultResponse(Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
 
exceptionalOperationResultResponse(Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - 类 中的方法org.apache.flink.runtime.rest.handler.PipelineErrorHandler
 
ExceptionHandler<E extends Throwable> - org.apache.flink.runtime.operators.sort中的接口
Interface to be implemented by classes that handle exceptions.
ExceptionInChainedStubException - org.apache.flink.runtime.operators.chaining中的异常错误
A special exception to indicate that an exception occurred in the nested call of a chained stub.
ExceptionInChainedStubException(String, Exception) - 异常错误 的构造器org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
exceptionUnwrap(Exception) - 异常错误 中的静态方法org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
excludeFromReset(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
executable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
executable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
execute(Runnable) - 类 中的方法org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
execute(Runnable) - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
execute(Runnable) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
execute(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Callable<T>) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
execute(Runnable) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Execute the given runnable in the executor of the RPC service.
execute(Callable<T>) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Execute the given callable and return its result as a CompletableFuture.
executeJobBlocking(JobGraph) - 接口 中的方法org.apache.flink.runtime.minicluster.JobExecutor
Run the given job and block until its execution result can be returned.
executeJobBlocking(JobGraph) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
This method runs a job in blocking mode.
Execution - org.apache.flink.runtime.executiongraph中的类
A single execution of a vertex.
Execution(Executor, ExecutionVertex, int, long, long, Time) - 类 的构造器org.apache.flink.runtime.executiongraph.Execution
Creates a new Execution attempt.
EXECUTION_MODE - 类 中的静态变量org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
EXECUTION_MODE_OPTION - 类 中的静态变量org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
已过时。
exists only for compatibility with legacy mode. Remove once legacy mode and execution mode option has been removed.
ExecutionAndAllocationFuture - org.apache.flink.runtime.executiongraph中的类
A pair of an Execution together with an allocation future.
ExecutionAndAllocationFuture(Execution, CompletableFuture<Void>) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
executionAttempt - 类 中的变量org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
ExecutionAttemptID - org.apache.flink.runtime.executiongraph中的类
Unique identifier for the attempt to execute a tasks.
ExecutionAttemptID() - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
ExecutionAttemptID(long, long) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
executionConfig - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
executionConfig - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
executionConfig - 类 中的变量org.apache.flink.runtime.state.DefaultKeyedStateStore
 
executionConfig - 类 中的变量org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
The execution configuration.
ExecutionConfigInfo(String, String, int, boolean, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
ExecutionEdge - org.apache.flink.runtime.executiongraph中的类
 
ExecutionEdge(IntermediateResultPartition, ExecutionVertex, int) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionEdge
 
ExecutionExceptionInfo(String, String, String, long) - 类 的构造器org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
ExecutionGraph - org.apache.flink.runtime.executiongraph中的类
The execution graph is the central data structure that coordinates the distributed execution of a data flow.
ExecutionGraph(JobInformation, ScheduledExecutorService, Executor, Time, RestartStrategy, FailoverStrategy.Factory, SlotProvider, ClassLoader, BlobWriter, Time) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionGraph
 
ExecutionGraphBuilder - org.apache.flink.runtime.executiongraph中的类
Utility class to encapsulate the logic of building an ExecutionGraph from a JobGraph.
ExecutionGraphCache - org.apache.flink.runtime.rest.handler.legacy中的类
Cache for ArchivedExecutionGraph which are obtained from the Flink cluster.
ExecutionGraphCache(Time, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
 
ExecutionGraphException - org.apache.flink.runtime.executiongraph中的异常错误
Base class for exceptions occurring in the ExecutionGraph.
ExecutionGraphException(String) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException - org.apache.flink.runtime.jobmaster中的异常错误
Exceptions thrown by operations on the ExecutionGraph by the JobMaster.
ExecutionGraphException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphRestartCallback - org.apache.flink.runtime.executiongraph.restart中的类
A RestartCallback that abstracts restart calls on an ExecutionGraph.
ExecutionGraphRestartCallback(ExecutionGraph, long) - 类 的构造器org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
Creates a new ExecutionGraphRestartCallback.
executionId() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
ExecutionJobVertex - org.apache.flink.runtime.executiongraph中的类
An ExecutionJobVertex is part of the ExecutionGraph, and the peer to the JobVertex.
ExecutionJobVertex(ExecutionGraph, JobVertex, int, Time, long, long) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ExecutionState - org.apache.flink.runtime.execution中的枚举
An enumeration of all states that a task can be in during its execution.
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - 接口 中的方法org.apache.flink.runtime.executiongraph.ExecutionStatusListener
Called whenever the execution status of a task changes.
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - 类 中的方法org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
ExecutionStatusListener - org.apache.flink.runtime.executiongraph中的接口
Interface for observers that monitor the status of individual task executions.
ExecutionVertex - org.apache.flink.runtime.executiongraph中的类
The ExecutionVertex is a parallel subtask of the execution.
ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Time, long, long, int) - 类 的构造器org.apache.flink.runtime.executiongraph.ExecutionVertex
Creates an ExecutionVertex.
executor - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
Executors - org.apache.flink.runtime.concurrent中的类
Collection of Executor, ExecutorService and ExecutionContext implementations.
Executors() - 类 的构造器org.apache.flink.runtime.concurrent.Executors
 
ExecutorThreadFactory - org.apache.flink.runtime.util中的类
A thread factory intended for use by critical thread pools.
ExecutorThreadFactory() - 类 的构造器org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the default thread pool name ('flink-executor-pool') and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String) - 类 的构造器org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String, Thread.UncaughtExceptionHandler) - 类 的构造器org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the given uncaught exception handler.
ExecutorThreadFactory.Builder - org.apache.flink.runtime.util中的类
 
exists() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
exists(String) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the version of the node if it exists or -1 if it doesn't.
exitMainThread() - 类 中的方法org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
expectedEntries - 类 中的变量org.apache.flink.runtime.operators.util.BloomFilter
 
expectedModVersion() - 异常错误 中的方法org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
expired(long, long, long) - 类 中的静态方法org.apache.flink.runtime.state.ttl.TtlUtils
 
EXTERNAL_POINTER - 类 中的静态变量org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
The external pointer returned for checkpoints that are not externally addressable.
ExternalizedCheckpointInfo(boolean, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
 
extract - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
extract - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
extractAndUploadJobGraphFiles(JobGraph, SupplierWithException<BlobClient, IOException>) - 枚举 中的静态方法org.apache.flink.runtime.client.ClientUtils
Extracts all files required for the execution from the given JobGraph and uploads them using the BlobClient from the given Supplier.
extractFromSystem(long) - 类 中的静态方法org.apache.flink.runtime.instance.HardwareDescription
 
extractImplementedRpcGateways(Class<?>) - 类 中的静态方法org.apache.flink.runtime.rpc.RpcUtils
Extracts all RpcGateway interfaces implemented by the given clazz.
extractKeyFromElement(T) - 接口 中的方法org.apache.flink.runtime.state.KeyExtractorFunction
Returns the key for the given element by which the key-group can be computed.
extractMaximumFramesize(Configuration) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 

F

Factory() - 类 的构造器org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
Factory() - 类 的构造器org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
Factory() - 类 的构造器org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
fail(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
This method fails the vertex due to an external condition.
fail(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
fail(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
fail(Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
Fail the payload with the given cause.
failAllocation(AllocationID, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Fails the slot with the given allocation id.
failAllocation(AllocationID, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
Fail the specified allocation and release the corresponding slot if we have one.
FailedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>, long, String) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
FailedCheckpointStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a failed checkpoint.
failExternally(Throwable) - 接口 中的方法org.apache.flink.runtime.execution.Environment
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
failExternally(Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
failExternally(Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
failExternally(Throwable) - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskActions
Fail the owning task with the given throwable.
failGlobal(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Fails the execution graph globally.
FailoverRegion - org.apache.flink.runtime.executiongraph.failover中的类
FailoverRegion manages the failover of a minimal pipeline connected sub graph.
FailoverRegion(ExecutionGraph, List<ExecutionVertex>) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
FailoverStrategy - org.apache.flink.runtime.executiongraph.failover中的类
A FailoverStrategy describes how the job computation recovers from task failures.
FailoverStrategy() - 类 的构造器org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
 
FailoverStrategy.Factory - org.apache.flink.runtime.executiongraph.failover中的接口
This factory is a necessary indirection when creating the FailoverStrategy to that we can have both the FailoverStrategy final in the ExecutionGraph, and the ExecutionGraph final in the FailOverStrategy.
FailoverStrategyLoader - org.apache.flink.runtime.executiongraph.failover中的类
A utility class to load failover strategies from the configuration.
FailoverStrategyLoader() - 类 的构造器org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
 
failPartition(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
failPartition(ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Fail all intermediate result partitions of the given task.
failPartition(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
failPartition(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
failPartition(ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Fail all intermediate result partitions of the given task.
failSlot(ResourceID, AllocationID, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
failSlot(ResourceID, AllocationID, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Fails the slot with the given allocation id and cause.
failTask(ExecutionAttemptID, Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
failTask(ExecutionAttemptID, Throwable) - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerActions
Tells the task manager to fail the given task.
failUnacknowledgedPendingCheckpointsFor(ExecutionAttemptID, Throwable) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Fails all pending checkpoints which have not been acknowledged by the given execution attempt id.
FailureRateRestartStrategy - org.apache.flink.runtime.executiongraph.restart中的类
Restart strategy which tries to restart the given ExecutionGraph when failure rate exceeded with a fixed time delay in between.
FailureRateRestartStrategy(int, Time, Time) - 类 的构造器org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
FailureRateRestartStrategy.FailureRateRestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
 
FailureRateRestartStrategyFactory(int, Time, Time) - 类 的构造器org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
FatalErrorHandler - org.apache.flink.runtime.rpc中的接口
Handler for fatal errors.
FatalErrorOccurred - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the Flink's resource manager in case of a fatal error that cannot be recovered in the running process.
FatalErrorOccurred(String, Throwable) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
FatalExitExceptionHandler - org.apache.flink.runtime.util中的类
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
FatalExitExceptionHandler() - 类 的构造器org.apache.flink.runtime.util.FatalExitExceptionHandler
 
FencedAkkaInvocationHandler<F extends Serializable> - org.apache.flink.runtime.rpc.akka中的类
Fenced extension of the AkkaInvocationHandler.
FencedAkkaInvocationHandler(String, String, ActorRef, Time, long, CompletableFuture<Void>, Supplier<F>) - 类 的构造器org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
FencedAkkaRpcActor<F extends Serializable,T extends FencedRpcEndpoint<F> & RpcGateway> - org.apache.flink.runtime.rpc.akka中的类
Fenced extension of the AkkaRpcActor.
FencedAkkaRpcActor(T, CompletableFuture<Boolean>, int, long) - 类 的构造器org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
FencedMainThreadExecutable - org.apache.flink.runtime.rpc中的接口
Extended MainThreadExecutable interface which allows to run unfenced runnables in the main thread.
FencedMessage<F extends Serializable,P> - org.apache.flink.runtime.rpc.messages中的接口
Interface for fenced messages.
FencedRpcEndpoint<F extends Serializable> - org.apache.flink.runtime.rpc中的类
Base class for fenced RpcEndpoint.
FencedRpcEndpoint(RpcService, String) - 类 的构造器org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
FencedRpcEndpoint(RpcService) - 类 的构造器org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
FencedRpcGateway<F extends Serializable> - org.apache.flink.runtime.rpc中的接口
Fenced RpcGateway.
fenceRpcServer(RpcServer, F) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
fenceRpcServer(RpcServer, F) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Fence the given RpcServer with the given fencing token.
FencingTokenException - org.apache.flink.runtime.rpc.exceptions中的异常错误
Exception which is thrown if the fencing tokens of a FencedRpcEndpoint do not match.
FencingTokenException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
FencingTokenException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
FencingTokenException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
FIELD_NAME_ACC_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
FIELD_NAME_ACC_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
FIELD_NAME_ACC_TYPE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
FIELD_NAME_ACC_TYPE - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
FIELD_NAME_ACC_VALUE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
FIELD_NAME_ACC_VALUE - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
FIELD_NAME_ACK_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_ADDRESS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_ALIGNMENT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_ALIGNMENT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
FIELD_NAME_ALIGNMENT_BUFFERED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
FIELD_NAME_ALIGNMENT_BUFFERED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_ALIGNMENT_BUFFERED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
FIELD_NAME_ALIGNMENT_BUFFERED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_ALIGNMENT_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
FIELD_NAME_ALL_EXCEPTIONS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
FIELD_NAME_ASYNC_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
FIELD_NAME_ASYNCHRONOUS_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
FIELD_NAME_ATTEMPT - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_ATTEMPT - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_ATTEMPT_NUM - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
FIELD_NAME_ATTEMPT_NUM - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
FIELD_NAME_AVERAGE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
FIELD_NAME_BACKPRESSURE_LEVEL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
FIELD_NAME_BACKPRESSURE_LEVEL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
FIELD_NAME_BUFFERED_DATA - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
FIELD_NAME_CHECKPOINT_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_CHECKPOINT_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
FIELD_NAME_CHECKPOINT_INTERVAL - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_CHECKPOINT_MAX_CONCURRENT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_CHECKPOINT_MIN_PAUSE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_CHECKPOINT_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
FIELD_NAME_CHECKPOINT_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_CHECKPOINT_TIMEOUT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_COMMIT - 类 中的静态变量org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
FIELD_NAME_COMPATIBLE_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_COMPLETED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
FIELD_NAME_COMPLETED_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
FIELD_NAME_CONFIG_KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
FIELD_NAME_CONFIG_VALUE - 类 中的静态变量org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
FIELD_NAME_COUNT - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
FIELD_NAME_COUNTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
FIELD_NAME_CPU_CORES - 类 中的静态变量org.apache.flink.runtime.instance.HardwareDescription
 
FIELD_NAME_DATA_PORT - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_DELETE_ON_CANCELLATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
 
FIELD_NAME_DIRECT_COUNT - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_DIRECT_MAX - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_DIRECT_USED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_DISCARDED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
FIELD_NAME_ENABLED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
 
FIELD_NAME_END_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_END_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_END_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_END_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
FIELD_NAME_EXCEPTION - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_EXECUTION_CONFIG - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo
 
FIELD_NAME_EXECUTION_MODE - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
FIELD_NAME_EXTERNAL_PATH - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
FIELD_NAME_EXTERNAL_PATH - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
FIELD_NAME_EXTERNALIZED_CHECKPOINT_CONFIG - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_FAILED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
FIELD_NAME_FAILED_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
FIELD_NAME_FAILURE_MESSAGE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
FIELD_NAME_FAILURE_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
FIELD_NAME_FLINK_REVISION - 类 中的静态变量org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
FIELD_NAME_FLINK_VERSION - 类 中的静态变量org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
FIELD_NAME_GARBAGE_COLLECTORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_GLOBAL_JOB_PARAMETERS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
FIELD_NAME_HARDWARE - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_HEAP_COMMITTED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_HEAP_MAX - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_HEAP_USED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_HISTORY - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
FIELD_NAME_HOST - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_HOST - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
FIELD_NAME_HOST - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_HOST - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
 
FIELD_NAME_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
FIELD_NAME_IN_PROGRESS_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
FIELD_NAME_INDEX - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
FIELD_NAME_IS_SAVEPOINT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
FIELD_NAME_IS_SAVEPOINT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_IS_STOPPABLE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOB_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
FIELD_NAME_JOB_GRAPH - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
FIELD_NAME_JOB_ID - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
FIELD_NAME_JOB_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOB_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo
 
FIELD_NAME_JOB_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOB_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo
 
FIELD_NAME_JOB_STATUS - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
FIELD_NAME_JOB_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOB_URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
 
FIELD_NAME_JOB_VERTEX_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_END_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
FIELD_NAME_JOB_VERTEX_INFOS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOB_VERTEX_METRICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTEX_STATE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_JOB_VERTICES_PER_STATE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_JOBS - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
FIELD_NAME_JOBS - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
FIELD_NAME_JOBS_CANCELLED - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
FIELD_NAME_JOBS_FAILED - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
FIELD_NAME_JOBS_FINISHED - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
FIELD_NAME_JOBS_RUNNING - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
FIELD_NAME_JSON_PLAN - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_LAST_HEARTBEAT - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_LATEST_ACK_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_LATEST_ACK_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_LATEST_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
FIELD_NAME_LOCATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_MAPPED_COUNT - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_MAPPED_MAX - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_MAPPED_USED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_MAXIMUM - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
FIELD_NAME_METRICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_METRICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_METRICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
FIELD_NAME_MINIMUM - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
FIELD_NAME_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
FIELD_NAME_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
FIELD_NAME_NETWORK_MEMORY_SEGMENTS_AVAILABLE - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NETWORK_MEMROY_SEGMENTS_TOTAL - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NON_HEAP_COMMITTED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NON_HEAP_MAX - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NON_HEAP_USED - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NOW - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_NOW - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
FIELD_NAME_NOW - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
FIELD_NAME_NUM_ACK_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_NUM_ACK_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_NUM_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_NUM_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_NUMBER_AVAILABLE_SLOTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_NUMBER_SLOTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_OBJECT_REUSE_MODE - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
FIELD_NAME_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
FIELD_NAME_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
FIELD_NAME_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
FIELD_NAME_PROCESSING_MODE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_RATIO - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
FIELD_NAME_REFRESH_INTERVAL - 类 中的静态变量org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
FIELD_NAME_RESOURCE_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
FIELD_NAME_RESTART_STRATEGY - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
FIELD_NAME_RESTORE_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
FIELD_NAME_RESTORED - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
FIELD_NAME_RESTORED_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
FIELD_NAME_ROOT_EXCEPTION - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
FIELD_NAME_SAVEPOINT - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
FIELD_NAME_SAVEPOINT_PATH - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
 
FIELD_NAME_SERIALIZED_USER_TASK_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
FIELD_NAME_SIZE_JVM_HEAP - 类 中的静态变量org.apache.flink.runtime.instance.HardwareDescription
 
FIELD_NAME_SIZE_MANAGED_MEMORY - 类 中的静态变量org.apache.flink.runtime.instance.HardwareDescription
 
FIELD_NAME_SIZE_PHYSICAL_MEMORY - 类 中的静态变量org.apache.flink.runtime.instance.HardwareDescription
 
FIELD_NAME_SLOTS_AVAILABLE - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
FIELD_NAME_SLOTS_TOTAL - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
FIELD_NAME_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
FIELD_NAME_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_STATE_SIZE - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
FIELD_NAME_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
FIELD_NAME_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_SUBTASK - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
FIELD_NAME_SUBTASK - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_SUBTASK - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
FIELD_NAME_SUBTASK_INDEX - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
FIELD_NAME_SUBTASK_INDEX - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_SUBTASK_INDEX - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
FIELD_NAME_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
FIELD_NAME_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
FIELD_NAME_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
FIELD_NAME_SUBTASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
FIELD_NAME_SUBTASKS_CHECKPOINT_STATISTICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
FIELD_NAME_SUMMARY - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
FIELD_NAME_SUMMARY - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
FIELD_NAME_SYNC_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
FIELD_NAME_SYNCHRONOUS_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
FIELD_NAME_TARGET_DIRECTORY - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
FIELD_NAME_TASK - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_TASK_MANAGERS - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
FIELD_NAME_TASKMANAGERS - 类 中的静态变量org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
FIELD_NAME_TASKS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_TASKS_PER_STATE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
FIELD_NAME_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
FIELD_NAME_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
FIELD_NAME_TIMESTAMPS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
FIELD_NAME_TIMESTAMPS - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
FIELD_NAME_TIMEZONE_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
FIELD_NAME_TIMEZONE_OFFSET - 类 中的静态变量org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
FIELD_NAME_TOTAL_CHECKPOINTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
FIELD_NAME_TRIGGER_TIMESTAMP - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_TRUNCATED - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
FIELD_NAME_USER_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
FIELD_NAME_USER_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
FIELD_NAME_USER_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
 
FIELD_NAME_USER_TASK_ACCUMULATORS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
FIELD_NAME_VERSION - 类 中的静态变量org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
FIELD_NAME_VERTEX_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
FIELD_NAME_VERTEX_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
FieldVisitorImpl(int) - 类 的构造器org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
FileArchivedExecutionGraphStore - org.apache.flink.runtime.dispatcher中的类
FileArchivedExecutionGraphStore(File, Time, long, ScheduledExecutor, Ticker) - 类 的构造器org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
FileBasedStateOutputStream - org.apache.flink.runtime.state.filesystem中的类
A CheckpointStreamFactory.CheckpointStateOutputStream that writes into a specified file and returns a FileStateHandle upon closing.
FileBasedStateOutputStream(FileSystem, Path) - 类 的构造器org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
FileCache - org.apache.flink.runtime.filecache中的类
The FileCache is used to access registered cache files when a task is deployed.
FileCache(String[], PermanentBlobService) - 类 的构造器org.apache.flink.runtime.filecache.FileCache
 
fileChannel - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
A file channel for NIO access to the file.
FileChannelInputView - org.apache.flink.runtime.io.disk中的类
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
FileChannelInputView(BlockChannelReader<MemorySegment>, MemoryManager, List<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.io.disk.FileChannelInputView
 
FileChannelOutputView - org.apache.flink.runtime.io.disk中的类
A DataOutputView that is backed by a BlockChannelWriter, making it effectively a data output stream.
FileChannelOutputView(BlockChannelWriter<MemorySegment>, MemoryManager, List<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.io.disk.FileChannelOutputView
 
FileIOChannel - org.apache.flink.runtime.io.disk.iomanager中的接口
A Channel represents a collection of files that belong logically to the same resource.
FileIOChannel.Enumerator - org.apache.flink.runtime.io.disk.iomanager中的类
An enumerator for channels that logically belong together.
FileIOChannel.ID - org.apache.flink.runtime.io.disk.iomanager中的类
An ID identifying an underlying file channel.
FileJobGraphRetriever - org.apache.flink.runtime.entrypoint.component中的类
JobGraphRetriever implementation which retrieves the JobGraph from a file on disk.
FileJobGraphRetriever(String) - 类 的构造器org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
 
fileName - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
FileSegment - org.apache.flink.runtime.io.disk.iomanager中的类
 
FileSegment(FileChannel, long, int, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
FileStateHandle - org.apache.flink.runtime.state.filesystem中的类
StreamStateHandle for state that was written to a file stream.
FileStateHandle(Path, long) - 类 的构造器org.apache.flink.runtime.state.filesystem.FileStateHandle
Creates a new file state for the given file path.
fileSystem - 类 中的变量org.apache.flink.runtime.state.SnapshotDirectory
The filesystem that contains the snapshot directory.
FileSystemBlobStore - org.apache.flink.runtime.blob中的类
Blob store backed by FileSystem.
FileSystemBlobStore(FileSystem, String) - 类 的构造器org.apache.flink.runtime.blob.FileSystemBlobStore
 
FileSystemStateStorageHelper<T extends Serializable> - org.apache.flink.runtime.zookeeper.filesystem中的类
RetrievableStateStorageHelper implementation which stores the state in the given filesystem path.
FileSystemStateStorageHelper(String, String) - 类 的构造器org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
FileSystemStateStorageHelper(Path, String) - 类 的构造器org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
FileType - org.apache.flink.runtime.taskexecutor中的枚举
Different file types to request from the TaskExecutor.
FileUpload - org.apache.flink.runtime.rest中的类
Client uploading a file.
FileUpload(Path, String) - 类 的构造器org.apache.flink.runtime.rest.FileUpload
 
FileUploadHandler - org.apache.flink.runtime.rest中的类
Writes multipart/form-data to disk.
FileUploadHandler(Path) - 类 的构造器org.apache.flink.runtime.rest.FileUploadHandler
 
FileUploads - org.apache.flink.runtime.rest.handler中的类
A container for uploaded files.
FileUploads(Path) - 类 的构造器org.apache.flink.runtime.rest.handler.FileUploads
 
filterOrTransform(T) - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotTransformer
Transform or filter out state values which are included or skipped in the snapshot.
filterOrTransform(List<T>) - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformer
 
filterOrTransform(Map<K, V>) - 类 中的方法org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformer
 
finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
finalizeCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
finalizeOnMaster(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master after the job completed.
finalizeOnMaster(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
finalStatus() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.StopCluster
 
find(Configuration) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
Finds the Flink log directory using log.file Java property that is set during startup.
findConnectingAddress(InetSocketAddress, long, long) - 类 中的静态方法org.apache.flink.runtime.net.ConnectionUtils
Finds the local network address from which this machine can connect to the target address.
findConnectingAddress(FiniteDuration) - 类 中的方法org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(FiniteDuration, FiniteDuration) - 类 中的方法org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(LeaderRetrievalService, Time) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findConnectingAddress(LeaderRetrievalService, FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findMatchingRequest(ResourceProfile) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot request for a given resource profile.
findMatchingSlot(ResourceProfile) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot for a given resource profile.
findVertexByID(JobVertexID) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Searches for a vertex with a matching ID and returns it.
finish() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
Mark this BufferBuilder and associated BufferConsumer as finished - no new data writes will be allowed.
finish() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Finishes the result partition.
finish() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
finishWriteAndSortKeys(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
firstDam() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
firstKeyGroup - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
Cached value of keyGroupRange#firstKeyGroup.
FixedDelayRestartStrategy - org.apache.flink.runtime.executiongraph.restart中的类
Restart strategy which tries to restart the given ExecutionGraph a fixed number of times with a fixed time delay in between.
FixedDelayRestartStrategy(int, long) - 类 的构造器org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
 
FixedDelayRestartStrategyFactory(int, long) - 类 的构造器org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
FixedLengthRecordSorter<T> - org.apache.flink.runtime.operators.sort中的类
 
FixedLengthRecordSorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
FixedThreadPoolExecutorConfiguration(int, int, int) - 类 的构造器org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
 
FLAG_LAST_BLOCK - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The flag marking a block as the last block.
FlatMapDriver<IT,OT> - org.apache.flink.runtime.operators中的类
Map task which is executed by a Task Manager.
FlatMapDriver() - 类 的构造器org.apache.flink.runtime.operators.FlatMapDriver
 
FlinkChillPackageRegistrar - org.apache.flink.runtime.types中的类
Creates a registrar for all the serializers in the chill.java package.
FlinkChillPackageRegistrar() - 类 的构造器org.apache.flink.runtime.types.FlinkChillPackageRegistrar
 
FlinkDistributionOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays Flink into a container, based on supplied bin/conf/lib directories.
FlinkDistributionOverlay(File, File, File) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
FlinkDistributionOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the FlinkDistributionOverlay.
FlinkHttpObjectAggregator - org.apache.flink.runtime.rest中的类
Same as HttpObjectDecoder but returns HTTP 413 to the client if the payload exceeds MessageAggregator.maxContentLength.
FlinkHttpObjectAggregator(int, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
 
FlinkJobNotFoundException - org.apache.flink.runtime.messages中的异常错误
Exception indicating that we could not find a Flink job with the given job ID.
FlinkJobNotFoundException(JobID) - 异常错误 的构造器org.apache.flink.runtime.messages.FlinkJobNotFoundException
 
FlinkParseException - org.apache.flink.runtime.entrypoint中的异常错误
Exception which indicates that the parsing of command line arguments failed.
FlinkParseException(String) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.FlinkParseException
 
FlinkParseException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.FlinkParseException
 
FlinkParseException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.entrypoint.FlinkParseException
 
FlinkUntypedActor - org.apache.flink.runtime.akka中的类
Base class for Flink's actors implemented with Java.
FlinkUntypedActor() - 类 的构造器org.apache.flink.runtime.akka.FlinkUntypedActor
 
FlinkUserCodeClassLoaders - org.apache.flink.runtime.execution.librarycache中的类
Gives the URLClassLoader a nicer name for debugging purposes.
FlinkUserCodeClassLoaders() - 类 的构造器org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
FlinkUserCodeClassLoaders.ResolveOrder - org.apache.flink.runtime.execution.librarycache中的枚举
Class resolution order for Flink URL ClassLoader.
FlinkZooKeeperQuorumPeer - org.apache.flink.runtime.zookeeper中的类
Simple wrapper for ZooKeeper's QuorumPeer, which reads a ZooKeeper config file and writes the required 'myid' file before starting the peer.
FlinkZooKeeperQuorumPeer() - 类 的构造器org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
 
flip() - 类 中的方法org.apache.flink.runtime.io.disk.SpillingBuffer
 
floatingNetworkBuffersPerGate() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
flush(int) - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Manually trigger consumption from enqueued BufferConsumers in one specified subpartition.
flush(int) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
flush() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
flush() - 类 中的方法org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
flush(ChannelHandlerContext, HttpRequest, HttpResponse) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
 
flush(Channel, HttpRequest, HttpResponse) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
 
flush() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
flush() - 类 中的方法org.apache.flink.runtime.util.ForwardingOutputStream
 
flushAll() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
flushAll() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Manually trigger consumption from enqueued BufferConsumers in all subpartitions.
flushAll() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
FOR_KEYED_OBJECTS - 接口 中的静态变量org.apache.flink.runtime.state.KeyExtractorFunction
 
FOR_PRIORITY_COMPARABLE_OBJECTS - 接口 中的静态变量org.apache.flink.runtime.state.PriorityComparator
 
forCheckpoint(CheckpointRetentionPolicy) - 类 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for a checkpoint.
forCheckpointWithDefaultLocation() - 类 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointOptions
 
forKeyedObjects() - 接口 中的静态方法org.apache.flink.runtime.state.KeyExtractorFunction
 
ForkJoinExecutorConfiguration(double, int, int) - 类 的构造器org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
format() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
formatLogString(String) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
formatLogString(String) - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
formatScope(JobManagerMetricGroup, JobID, String) - 类 中的方法org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
 
formatScope(String) - 类 中的方法org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
 
formatScope(TaskMetricGroup, OperatorID, String) - 类 中的方法org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
formatScope(TaskManagerMetricGroup, JobID, String) - 类 中的方法org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
 
formatScope(String, String) - 类 中的方法org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
 
formatScope(TaskManagerJobMetricGroup, AbstractID, AbstractID, String, int, int) - 类 中的方法org.apache.flink.runtime.metrics.scope.TaskScopeFormat
 
formatSystemProperties(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.ContainerSpecification
Format the system properties as a shell-compatible command-line argument.
forPath(String) - 类 中的静态方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
forPath(String, boolean) - 类 中的静态方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
forPriorityComparableObjects() - 接口 中的静态方法org.apache.flink.runtime.state.PriorityComparator
 
forSavepoint() - 类 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for a (manually triggered) savepoint.
forUpdatedSerializer(TypeSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
Returns a deep copy of the snapshot, where the serializer is changed to the given serializer.
forward(Object, ActorGateway) - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Forwards a message.
forward(Object, ActorGateway) - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Forwards a message.
ForwardingInputStream - org.apache.flink.runtime.util中的类
Input stream, that wraps another input stream and forwards all method calls to the wrapped stream.
ForwardingInputStream(InputStream) - 类 的构造器org.apache.flink.runtime.util.ForwardingInputStream
 
ForwardingOutputStream - org.apache.flink.runtime.util中的类
Output stream, that wraps another input stream and forwards all method calls to the wrapped stream.
ForwardingOutputStream(OutputStream) - 类 的构造器org.apache.flink.runtime.util.ForwardingOutputStream
 
FreeingBufferRecycler - org.apache.flink.runtime.io.network.buffer中的类
A simple buffer recycler that frees the memory segments.
freeSlot() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
freeSlot(AllocationID, Throwable, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
freeSlot(AllocationID, Throwable, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Frees the slot with the given allocation ID.
freeSlot(AllocationID, Throwable, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
freeSlot(SlotID, AllocationID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Free the given slot from the given allocation.
freeSlot() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
freeSlot(AllocationID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotActions
Free the task slot with the given allocation id.
freeSlot(AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Try to free the slot.
freeSlot(AllocationID, Throwable) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Tries to free the slot.
freeSlot(AllocationID, Throwable, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
freeSlot(AllocationID, Throwable, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Frees the slot with the given allocation ID.
from(IntermediateResultPartition, int, boolean) - 类 中的静态方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
from(Configuration) - 类 中的静态方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
from(long, ZonedDateTime) - 类 中的静态方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
fromApplicationOrConfigOrDefault(StateBackend, Configuration, ClassLoader, Logger) - 类 中的静态方法org.apache.flink.runtime.state.StateBackendLoader
Checks if an application-defined state backend is given, and if not, loads the state backend from the configuration, from the parameter 'state.backend', as defined in CheckpointingOptions.STATE_BACKEND.
fromBuffer(Buffer, ClassLoader) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
fromByteBuf(ByteBuf) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
fromByteBuf(ByteBuf) - 类 中的静态方法org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
fromByteBuf(ByteBuf) - 类 中的静态方法org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
fromConfig(Configuration) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Return the configured HighAvailabilityMode.
fromConfig(Configuration) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormats
Creates the scope formats as defined in the given configuration.
fromConfig(Configuration) - 枚举 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
Return the configured ZooKeeperUtils.ZkClientACLMode.
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates an HeartbeatServices instance from a Configuration.
fromConfiguration(Configuration, BlobServer) - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.DefaultSchedulerFactory
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
Create a metric registry configuration object from the given Configuration.
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
fromConfiguration(ResourceManagerRuntimeServicesConfiguration, HighAvailabilityServices, ScheduledExecutor) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
fromConfiguration(Configuration, MetricQueryServiceRetriever, GatewayRetriever<T>, ExecutorService) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.rest.RestClientConfiguration
Creates and returns a new RestClientConfiguration from the given Configuration.
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Creates and returns a new RestServerEndpointConfiguration from the given Configuration.
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
fromConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
fromConfiguration(TaskManagerServicesConfiguration, ResourceID, Executor, long, long) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
Creates and returns the task manager services.
fromConfiguration(Configuration, InetAddress, boolean) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
fromEdge(IntermediateResultPartition, Execution) - 类 中的静态方法org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a partial input channel for the given partition and producing task.
fromEdges(ExecutionEdge[], ResourceID, boolean) - 类 中的静态方法org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
Creates an input channel deployment descriptor for each partition.
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
Configures the overlay using the current environment's Hadoop configuration.
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
Configures the overlay using the current Hadoop user information (from UserGroupInformation).
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
Configures the overlay using the current environment (and global configuration).
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
Configures the overlay using the current environment (and global configuration).
fromHexString(String) - 类 中的静态方法org.apache.flink.runtime.jobgraph.JobVertexID
 
fromHexString(String) - 类 中的静态方法org.apache.flink.runtime.rest.messages.TriggerId
 
fromJobStatus(JobStatus) - 枚举 中的静态方法org.apache.flink.runtime.clusterframework.ApplicationStatus
Derives the ApplicationStatus that should be used for a job that resulted in the given job status.
fromJobVertexID(JobVertexID) - 类 中的静态方法org.apache.flink.runtime.jobgraph.OperatorID
 
fromKeyValueJsonArray(String) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
fromMetaInfoSnapshot(StateMetaInfoSnapshot) - 类 中的静态方法org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
 
fromNewRegisteredSerializer(TypeSerializer<T>) - 类 中的静态方法org.apache.flink.runtime.state.StateSerializerProvider
Creates a StateSerializerProvider from the registered state serializer.
fromPreviousSerializerSnapshot(TypeSerializerSnapshot<T>) - 类 中的静态方法org.apache.flink.runtime.state.StateSerializerProvider
Creates a StateSerializerProvider for restored state from the previous serializer's snapshot.
fromRequestBodyOrQueryParameter(T, SupplierWithException<T, RestHandlerException>, T, Logger) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
Returns requestValue if it is not null, otherwise returns the query parameter value if it is not null, otherwise returns the default value.
fromSerializedEvent(ByteBuffer, ClassLoader) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
fromStatusOverview(ClusterOverview, String, String) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
fromString(String) - 枚举 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
 
fromURLVersionPrefix(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
Converts the given URL version prefix (e.g "v1") to a RestAPIVersion.
fromUuid(UUID) - 类 中的静态方法org.apache.flink.runtime.dispatcher.DispatcherId
Creates a new DispatcherId that corresponds to the UUID.
fromUuid(UUID) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManagerId
Creates a ResourceManagerId that corresponds to the given UUID.
fromUuidOrNull(UUID) - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobMasterId
If the given uuid is null, this returns null, otherwise a JobMasterId that corresponds to the UUID, via JobMasterId.JobMasterId(UUID).
fromUuidOrNull(UUID) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManagerId
If the given uuid is null, this returns null, otherwise a ResourceManagerId that corresponds to the UUID, via ResourceManagerId.ResourceManagerId(UUID).
FrontMetricGroup<P extends AbstractMetricGroup<?>> - org.apache.flink.runtime.metrics.groups中的类
Metric group which forwards all registration calls to a variable parent metric group that injects a variable reporter index into calls to MetricGroup.getMetricIdentifier(String) or MetricGroup.getMetricIdentifier(String, CharacterFilter).
FrontMetricGroup(int, P) - 类 的构造器org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
FS_STATE_BACKEND_NAME - 类 中的静态变量org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the FileSystem State backend
FsCheckpointMetadataOutputStream - org.apache.flink.runtime.state.filesystem中的类
A CheckpointMetadataOutputStream that writes a specified file and directory, and returns a FsCompletedCheckpointStorageLocation upon closing.
FsCheckpointMetadataOutputStream(FileSystem, Path, Path) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
FsCheckpointStateOutputStream(Path, FileSystem, int, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
FsCheckpointStorage - org.apache.flink.runtime.state.filesystem中的类
An implementation of durable checkpoint storage to file systems.
FsCheckpointStorage(Path, Path, JobID, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
FsCheckpointStorage(FileSystem, Path, Path, JobID, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
FsCheckpointStorageLocation - org.apache.flink.runtime.state.filesystem中的类
A storage location for checkpoints on a file system.
FsCheckpointStorageLocation(FileSystem, Path, Path, Path, CheckpointStorageLocationReference, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
FsCheckpointStreamFactory - org.apache.flink.runtime.state.filesystem中的类
A CheckpointStreamFactory that produces streams that write to a FileSystem.
FsCheckpointStreamFactory(FileSystem, Path, Path, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
Creates a new stream factory that stores its checkpoint data in the file system and location defined by the given Path.
FsCheckpointStreamFactory.FsCheckpointStateOutputStream - org.apache.flink.runtime.state.filesystem中的类
A CheckpointStreamFactory.CheckpointStateOutputStream that writes into a file and returns a StreamStateHandle upon closing.
FsCompletedCheckpointStorageLocation - org.apache.flink.runtime.state.filesystem中的类
A CompletedCheckpointStorageLocation that resides on a file system.
FsCompletedCheckpointStorageLocation(FileSystem, Path, FileStateHandle, String) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
 
FsJobArchivist - org.apache.flink.runtime.history中的类
Utility class for writing an archive file to a FileSystem and reading it back.
FsNegativeRunningJobsRegistry - org.apache.flink.runtime.highavailability中的类
This RunningJobsRegistry tracks the status jobs via marker files, marking running jobs via running marker files, marking finished jobs via finished marker files.
FsNegativeRunningJobsRegistry(Path) - 类 的构造器org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes to the FileSystem and working directory denoted by the given path.
FsNegativeRunningJobsRegistry(FileSystem, Path) - 类 的构造器org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes its files to the given FileSystem at the given working directory path.
FsStateBackend - org.apache.flink.runtime.state.filesystem中的类
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
FsStateBackend(String) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(String, boolean) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path, boolean) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, URI) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, boolean) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int, boolean) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, URI, int, TernaryBoolean) - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackendFactory - org.apache.flink.runtime.state.filesystem中的类
A factory that creates an FsStateBackend from a configuration.
FsStateBackendFactory() - 类 的构造器org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
FULL_RESTART_STRATEGY_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartAllStrategy
FullOuterJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
The full outer join driver implements the logic of an outer join operator at runtime.
FullOuterJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.FullOuterJoinDriver
 
FunctionInitializationContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which user functions can initialize by registering to managed state (i.e. state that is managed by state backends).
FunctionSnapshotContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which user functions that use managed state (i.e. state that is managed by state backends) can participate in a snapshot.
furtherPartitioning - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
furtherPartitioning - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
 
future() - 类 中的方法org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
Gets the future that is completed with the leader address and ID.
FutureUtils - org.apache.flink.runtime.concurrent中的类
A collection of utilities that expand the usage of CompletableFuture.
FutureUtils() - 类 的构造器org.apache.flink.runtime.concurrent.FutureUtils
 
FutureUtils.ConjunctFuture<T> - org.apache.flink.runtime.concurrent中的类
A future that is complete once multiple other futures completed.
FutureUtils.RetryException - org.apache.flink.runtime.concurrent中的异常错误
Exception with which the returned future is completed if the FutureUtils.retry(Supplier, int, Executor) operation fails.

G

GarbageCollectorInfo(String, long, long) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
garbageCollectorNames - 类 中的变量org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskManagerMetricStore
 
GatewayRetriever<T extends RpcGateway> - org.apache.flink.runtime.webmonitor.retriever中的接口
Generic retriever interface for RpcGateway.
gauge(int, G) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(String, G) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(int, G) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
gauge(String, G) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
GaugeDump(QueryScopeInfo, String, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
generate() - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.ResourceID
Generate a random resource id.
generate() - 类 中的静态方法org.apache.flink.runtime.dispatcher.DispatcherId
Generates a new random DispatcherId.
generate() - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobMasterId
Generates a new random JobMasterId.
generate() - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ResourceManagerId
Generates a new random ResourceManagerId.
generate() - 类 中的静态方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotId
 
generateCheckpointStatistics(AbstractCheckpointStats, boolean) - 类 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
generateEndpointIdWithUUID() - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherFactory
 
generateEndpointIdWithUUID() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
 
generatePlan(JobGraph) - 类 中的静态方法org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
generateRegistration() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
This method generate a specific Registration, for example TaskExecutor Registration at the ResourceManager.
generateRegistration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
generateSlotOffer() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Generate the slot offer from this TaskSlot.
generateTaskManagerConfiguration(Configuration, String, int, int, FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Generate a task manager configuration.
generateZookeeperPath(String, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
 
GenericKeyMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A GenericMetricGroup for representing the key part of a key-value metric group pair.
GenericMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A simple named MetricGroup that is used to hold subgroups of metrics.
GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
GenericValueMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A GenericMetricGroup for representing the value part of a key-value metric group pair.
get(JobID, BlobKey, File) - 接口 中的方法org.apache.flink.runtime.blob.BlobView
Copies a blob to a local file.
get(JobID, BlobKey, File) - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
get(JobID, BlobKey, File) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
get() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
Gets the singleton instance.
get() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
Gets the singleton instance.
get() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
Gets the singleton instance.
get() - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
get(long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
get(JobID) - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Get the ArchivedExecutionGraph for the given job id.
get(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
get(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
get(String) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.Broker
Blocking retrieval and removal of the object to share.
get() - 类 中的静态方法org.apache.flink.runtime.messages.Acknowledge
Gets the singleton instance.
get(int) - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
Returns true if the bit is set in the specified index.
get(int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Returns true if the bit is set in the specified index.
get(int) - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
Get the state handle for a single operator in the operator chain by it's index.
get() - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
get(long, TimeUnit) - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
get(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
get(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
get(N) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Returns the state for the composite of active key and given namespace.
get(K) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
get() - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
get() - 类 中的静态方法org.apache.flink.runtime.state.VoidNamespace
Getter for the singleton instance
get(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerTable
 
get() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
get() - 类 中的静态方法org.apache.flink.runtime.util.EmptyIterator
Gets a singleton instance of the empty iterator.
get() - 类 中的静态方法org.apache.flink.runtime.util.EmptyMutableObjectIterator
Gets a singleton instance of the empty iterator.
get(int) - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
getAccumulatorRegistry() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Return the registry for accumulators which are periodically sent to the job manager.
getAccumulatorRegistry() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAccumulatorRegistry() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getAccumulatorResults() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
 
getAccumulatorResultsStringified() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the aggregated user-defined accumulators as strings.
getAccumulatorResultsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAccumulatorResultsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the a stringified version of the user-defined accumulators.
getAccumulators() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets flink and user-defined accumulators in serialized form.
getAccumulatorSnapshots() - 类 中的方法org.apache.flink.runtime.taskexecutor.AccumulatorReport
 
getAccumulatorsSerialized() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a map containing the serialized values of user-defined accumulators.
getAccumulatorsSerialized() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAccumulatorsSerialized() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets a serialized accumulator map.
getAckTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the timestamp when the acknowledgement of this subtask was received at the coordinator.
getAckTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getAckTimestampStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the ACK timestamps.
getAclForPath(String) - 类 中的方法org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getActiveSlots(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of active slots (their application ids) for the given job id.
getActorGateway() - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
getActorGatewayFuture() - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
getActorSystem() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getActual() - 异常错误 中的方法org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getAddress() - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
 
getAddress() - 异常错误 中的方法org.apache.flink.runtime.io.network.netty.exception.TransportException
 
getAddress() - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
getAddress() - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Return the address of the task manager with which the gateway is associated.
getAddress() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getAddress() - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterService
Get the address of the JobMaster service under which it is reachable.
getAddress() - 类 中的方法org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
getAddress() - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
getAddress() - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderContender
Returns the address of the LeaderContender under which other instances can connect to it.
getAddress() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getAddress() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getAddress() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Gets the address of the underlying RPC endpoint.
getAddress() - 接口 中的方法org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified address under which the associated rpc endpoint is reachable.
getAddress() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Return the hostname or host address under which the rpc service can be reached.
getAddress() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
 
getAddress() - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
getAddress() - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
 
getAddress() - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
getAggregatedUserAccumulatorsStringified() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the aggregated user-defined accumulators as strings.
getAggregatedUserAccumulatorsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getAggregatedUserAccumulatorsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregateJobVertexState(int[], int) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
A utility function that computes an "aggregated" state for the vertex.
getAggregates() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
getAggregates(ClassLoader) - 类 中的方法org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
getAggregateState() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the aggregated ExecutionState for this job vertex.
getAggregateState() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getAggregateState() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getAggregator(String) - 类 中的方法org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getAggregatorNames() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
getAggregatorNames() - 类 中的方法org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
getAkkaConfig() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
 
getAkkaConfig() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
getAlignment() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the number of bytes buffered during stream alignment (for exactly-once only).
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
getAlignmentBuffered() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getAlignmentBufferedStats() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the bytes buffered during alignment.
getAlignmentBufferedStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the buffered bytes during alignments.
getAlignmentDuration() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the stream alignment (for exactly-once only).
getAlignmentDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
getAlignmentDurationNanos() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAlignmentDurationStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the alignment duration.
getAllAggregators() - 类 中的方法org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getAllAndLock() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper and locks the respective state nodes.
getAllCheckpoints() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns all CompletedCheckpoint instances.
getAllCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getAllCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getAllExecutionVertexes() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverRegion
get all execution vertexes contained in this region
getAllExecutionVertices() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns an iterable containing all execution vertices for this execution graph.
getAllExecutionVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAllExecutionVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllInputGates() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getAllInputGates() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAllInputGates() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getAllIntermediateResults() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllocatedSlotInfos() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotReport
 
getAllocatedSlots() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
getAllocatedSlots(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of allocated slots for the given job id.
getAllocationId() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlotContext
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
 
getAllocationId() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the allocation id of this slot.
getAllocationId() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotInfo
Gets the id under which the slot has been allocated on the TaskManager.
getAllocationId() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.resourcemanager.SlotRequest
Get the unique identification of this request
getAllocationId() - 异常错误 中的方法org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getAllocationId() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getAllocationID() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
Get the allocation id of this slot.
getAllocationId() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getAllocationIdsPerJob(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Returns the all AllocationID for the given job.
getAllocationTimeout() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllowQueuedScheduling() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
getAllPaths() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Return a list of all valid paths for state handles.
getAllRegisteredInstances() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getAllSubtaskMetricStores() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
 
getAllTaskStateStats() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns all task state stats instances.
getAllVariables() - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
getAllVariables() - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getAllVertices() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a map containing all job vertices for this execution graph.
getAllVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAllVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllWriters() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getAllWriters() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAlwaysParentFirstLoaderPatterns() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getAndIncrement() - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Atomically increments the current checkpoint ID.
getAndIncrement() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
getAndIncrement() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
getAndLock(String) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets the RetrievableStateHandle stored in the given ZooKeeper node and locks it.
getAndRemove(String) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.Broker
Blocking retrieval and removal of the object to share.
getAndResetUnannouncedCredit() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Gets the unannounced credit and resets it to 0 atomically.
getAppConfigurationEntry(String) - 类 中的方法org.apache.flink.runtime.security.DynamicConfiguration
Retrieve the AppConfigurationEntries for the specified name from this Configuration.
getApplicationStatus() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
 
getArchivedExecutionConfig() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the ArchivedExecutionConfig for this execution graph.
getArchivedExecutionConfig() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getArchivedExecutionConfig() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the serializable ArchivedExecutionConfig.
getArchivedJsons(Path) - 类 中的静态方法org.apache.flink.runtime.history.FsJobArchivist
Reads the given archive file and returns a Collection of contained ArchivedJson.
getArgs() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
getArgs() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getArgs() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getArgs() - 接口 中的方法org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the arguments of the remote procedure call
getArity() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getArtifacts() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the container artifacts.
getAssignedAllocationID() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAssignedAllocationID() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getAssignedPendingSlotRequest() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
getAssignedPendingTaskManagerSlot() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getAssignedResource() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getAssignedResourceLocation() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the TaskManagerLocation for this execution.
getAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getAssignedSlotRequest() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAssignmentMode() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
getAssignmentMode() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
getAsyncCheckpointDuration() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the asynchronous part of the checkpoint.
getAsyncCheckpointDurationStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the async checkpoint duration.
getAsyncDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
getAsyncDurationMillis() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAsyncExecutor() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the async executor which executes outside of the main thread of the ResourceManager
getAsynchronousDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
getAttempt() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getAttemptId() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the ExecutionAttemptID for this Execution.
getAttemptId() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAttemptId() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getAttemptNumber() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the attempt number of the subtask.
getAttemptNumber() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the attempt number for this execution.
getAttemptNumber() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAttemptNumber() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getAvailableJobDetails() - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Return the collection of JobDetails of all currently stored jobs.
getAvailableJobDetails(JobID) - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Return the JobDetails} for the given job.
getAvailableJobDetails() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getAvailableJobDetails(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getAvailableJobDetails() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getAvailableJobDetails(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getAvailableSlots() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
getAvailableSlotsInformation() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
getAverage() - 类 中的方法org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Calculates the average over all seen values.
getAverage() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
getAvg() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getBackendIdentifier() - 接口 中的方法org.apache.flink.runtime.state.IncrementalKeyedStateHandle
Returns the identifier of the state backend from which this handle was created.
getBackendIdentifier() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getBackendIdentifier() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getBackendStateType() - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getBackpressureLevel() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
getBackpressureLevel() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
getBackPressureRatio(int) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getBasePath() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
已过时。
Deprecated in favor of FsStateBackend.getCheckpointPath().
getBlobManagerPort() - 类 中的方法org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getBlobServerHostname() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterInformation
 
getBlobServerPort(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
getBlobServerPort(Time) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherGateway
Returns the port of the blob server.
getBlobServerPort() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterInformation
 
getBlobWriter() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getBlobWriter() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getBlockCount() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
Gets the number of blocks written by this output view.
getBlockCount() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Gets the number of blocks used by this view.
getBlockCount() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
getBlockCount() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
getBroadcastGroupSize(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastInputName(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastInputSerializer(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastState(MapStateDescriptor<K, V>) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getBroadcastStateMetaInfoSnapshots() - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getBroadcastVariable(String) - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
getBroadcastVariableManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getBroadcastVariableManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getBroadcastVariableManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
getBuffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getBufferedData() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
getBufferPool() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getBufferPool() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBufferProvider() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getBufferProvider() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getBufferProvider() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBuffersInBacklog() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Gets the number of non-event buffers in this subpartition.
getBuildSideBlockCount() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideChannel() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideComparator() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getBuildSideIterator() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getBuildSideRecordCount() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideSerializer() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getBytes(int, ByteBuf, int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, byte[], int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, ByteBuffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, OutputStream, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, GatheringByteChannel, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, FileChannel, long, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytesBufferedInAlignment() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getBytesInLatestSegment() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
Gets the number of bytes written in the latest memory segment.
getBytesMemoryUsed() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
getBytesWritten() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Gets the number of pay-load bytes already written.
getBytesWritten() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
getCacheSize() - 类 中的方法org.apache.flink.runtime.query.KvStateEntry
 
getCallable() - 类 中的方法org.apache.flink.runtime.rpc.messages.CallAsync
 
getCapacity() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Gets the total capacity of this hash table, in bytes.
getCapacity() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getCapacity() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the total capacity of this sorter, in bytes.
getCapacity() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump
Returns the category for this MetricDump.
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Returns the category for this QueryScopeInfo.
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
getCategory() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
getChainedStubConfig(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getChainedTask(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getChainedTaskName(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getChainLength() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getChannel() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
getChannelID() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getChannelID() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Gets the channel ID of this I/O channel.
getChannelIndex() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getCheckpointAlignment() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
getCheckpointById(long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointCoordinator() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointCoordinatorConfiguration() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the CheckpointCoordinatorConfiguration or null if checkpointing is disabled.
getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getCheckpointDeclineReason() - 异常错误 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerException
 
getCheckpointDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getCheckpointDirectoryForJob(Path, JobID) - 类 中的静态方法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() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getCheckpointDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the ID of this checkpoint.
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
getCheckpointID() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the ID of this checkpoint.
getCheckpointId() - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the checkpoint ID of the savepoint.
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getCheckpointId() - 接口 中的方法org.apache.flink.runtime.state.IncrementalKeyedStateHandle
Returns the ID of the checkpoint for which the handle was created.
getCheckpointId() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getCheckpointId() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getCheckpointId() - 接口 中的方法org.apache.flink.runtime.state.ManagedSnapshotContext
Returns the ID of the checkpoint for which the snapshot is taken.
getCheckpointId() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getCheckpointIdCounter() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointingSettings() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Gets the settings for asynchronous snapshots.
getCheckpointInterval() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getCheckpointMetrics() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getCheckpointOptions() - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getCheckpointOptions() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
getCheckpointOutputStream() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
Returns the encapsulated output stream.
getCheckpointOutputStream() - 类 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
 
getCheckpointOutputStream() - 类 中的方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
 
getCheckpointPath() - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Gets the checkpoint base directory.
getCheckpointPath() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the base directory where all the checkpoints are stored.
getCheckpointRecoveryFactory() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the checkpoint recovery factory for the job manager
getCheckpointRecoveryFactory() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getCheckpointRecoveryFactory() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getCheckpointResponder() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getCheckpointRetentionPolicy() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointsDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
getCheckpointStatisticsPerTask() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getCheckpointStatsSnapshot() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a snapshot of the checkpoint statistics or null if checkpointing is disabled.
getCheckpointStatsSnapshot() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointStatsSnapshot() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
getCheckpointStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getCheckpointStorage() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointStore() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointTimeout() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointTimeout() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getCheckpointTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCheckpointTimestamp() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getCheckpointType() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointOptions
Returns the type of checkpoint to perform.
getCheckpointType() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
Gets the type of the checkpoint (checkpoint / savepoint).
getClassLoader(JobID) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getClassLoader(JobID) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Returns the user code class loader associated with id.
getClassLoaderResolveOrder() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getClasspaths() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
getCleanUpInterval() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Cleanup interval for completed stats cache.
getClientChannelHandlers() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyProtocol
Returns the client channel handlers.
getClientConnectTimeoutSeconds() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClientNumThreads() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClusterInformation() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getClusterInformation() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the cluster information.
GetClusterStatus - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the resource manager to request a GetClusterStatusResponse which contains the current number of task managers and the total number of task slots.
GetClusterStatusResponse - org.apache.flink.runtime.clusterframework.messages中的类
The reply to a GetClusterStatus message sent by the job manager.
GetClusterStatusResponse(int, int) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
getCoLocationConstraint() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getCoLocationGroup() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getCoLocationGroup() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getCommitId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
getComparatorWithCurrentReference() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
 
getComparatorWithCurrentReference() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator
 
getCompatibleVersions() - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getCompatibleVersions() - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getCompletedCheckpointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getCompletionFuture() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Returns the completion future.
getComponentMetricStore(HandlerRequest<EmptyRequestBody, M>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
Returns the MetricStore.ComponentMetricStore that should be queried for metrics.
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobManagerMetricsMessageParameters>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobMetricsMessageParameters>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobVertexMetricsMessageParameters>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
已过时。
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, SubtaskMetricsMessageParameters>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, TaskManagerMetricsMessageParameters>, MetricStore) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
 
getCompressionDecorator(ExecutionConfig) - 类 中的静态方法org.apache.flink.runtime.state.AbstractStateBackend
 
getConfig() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getConfigDir() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
getConfigDir() - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getConfigDir() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
getConfiguration() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getConfiguration() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getConfiguration() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
Gets the configuration that holds the actual values encoded.
getConfiguration() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
getConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getConfiguration() - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets the configuration that the TaskManager was started with.
getConfiguredMemory() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns the size of the managed memory (in megabytes), if configured.
getConnectionId() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
getConnectionId() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
getConnectionIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getConnectionIndex() - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
 
getConnectionManager() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getConnectionTimeout() - 类 中的方法org.apache.flink.runtime.rest.RestClientConfiguration
RestOptions.CONNECTION_TIMEOUT.
getConsumedPartitionId() - 类 中的方法org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionLocation() - 类 中的方法org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionType() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
Returns the type of this input channel's consumed result partition.
getConsumedPartitionType() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Returns the type of this input channel's consumed result partition.
getConsumedResultId() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getConsumedResultId() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getConsumedSubpartitionIndex() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getConsumers() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getConsumers() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getContainingTask() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getContainingTask() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getContentType() - 类 中的方法org.apache.flink.runtime.rest.FileUpload
 
getConvergenceCriterion(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getConvergenceCriterionAggregatorName() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getCount() - 类 中的方法org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the count of all seen values.
getCount() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
getCounts() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted checkpoint counts.
getCounts() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
getCpuCores() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the cpu cores needed.
getCpuIdle() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuIrq() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuLoad1() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuLoad15() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuLoad5() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuNice() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuSoftIrq() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuSys() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuUsage() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuUsagePerProcessor(int) - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCpuUser() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getCreateDump() - 类 中的静态方法org.apache.flink.runtime.metrics.dump.MetricQueryService
 
getCreationTimestamp() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getCurrent() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
 
getCurrent() - 接口 中的方法org.apache.flink.runtime.util.KeyGroupedIterator
 
getCurrent() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
 
getCurrent() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator
 
getCurrentAllocation(int) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the current allocation for the task slot with the given index.
getCurrentAssignedResource() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentAssignedResourceLocation() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the TaskManagerLocation for this execution vertex.
getCurrentAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getCurrentAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentBackoff() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Returns the current backoff in ms.
getCurrentBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
getCurrentBuffer() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
getCurrentConfiguration() - 类 中的方法org.apache.flink.runtime.security.modules.JaasModule
 
getCurrentExecutionAttempt() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the current execution for this execution vertex.
getCurrentExecutionAttempt() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getCurrentExecutionAttempt() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentKey() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getCurrentKey() - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
Used by states to access the current key.
getCurrentKeyGroup() - 类 中的方法org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns the key group that is currently being written.
getCurrentKeyGroupIndex() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getCurrentKeyGroupIndex() - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the key-group to which the current key belongs.
getCurrentNumberOfSubtasks() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the current number of subtasks the respective task is split into.
getCurrentOffset() - 类 中的方法org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
 
getCurrentPositionInSegment() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the position from which the next byte will be read.
getCurrentPositionInSegment() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getCurrentRestartAttempt() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
getCurrentSegment() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the memory segment that will be used to read the next bytes from.
getCurrentSegment() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the segment that the view currently writes to.
getCurrentSegmentLimit() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the current limit in the memory segment.
getCurrentTaskManagerLocationFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getData() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getDataPort() - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
 
getDataPort() - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
getDataPort() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
getDataPort() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getDataPort() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getDefault() - 类 中的静态方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
getDefaultAcl() - 类 中的方法org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getDefaultElement() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
getDefaultIOMode() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getDefaultMimeType() - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.MimeTypes
Gets the default MIME type, which is "application/octet-stream".
getDefaultSavepointDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Gets the default directory for savepoints.
getDefaultStateBackend() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getDefaultValue() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
 
getDelay(TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
getDelegateStateHandle() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getDelegateStateHandle() - 接口 中的方法org.apache.flink.runtime.state.OperatorStateHandle
Returns the underlying stream state handle that points to the state data.
getDelegateStateHandle() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
getDelimiter() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Returns the global delimiter.
getDelimiter(int) - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Returns the configured delimiter for the reporter with the given index.
getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getDelimiter(int) - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getDelimiter(int) - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getDescription() - 接口 中的方法org.apache.flink.runtime.rest.messages.MessageHeaders
Returns the description for this header.
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Returns a description for REST API HTML documentation.
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
getDirectMemoryInMB() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the direct memory needed in MB.
getDirectMemoryStatsAsString(BufferPoolMXBean) - 类 中的静态方法org.apache.flink.runtime.taskmanager.MemoryLogger
Returns a String with the direct memory footprint.
getDirectory() - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
getDirectory() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
getDirectoryStateHandle() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getDispatcher() - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
 
getDispatcherGatewayFuture() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getDispatcherLeaderElectionService() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the cluster's dispatcher.
getDispatcherLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getDispatcherLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getDispatcherLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getDispatcherLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader retriever for the dispatcher.
getDispatcherLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getDispatcherLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getDispatcherLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getDispatcherResourceManagerComponents() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getDistributedCacheEntries() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getDistributedCacheEntries() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getDistributionMode() - 类 中的方法org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
getDistributionPattern() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Returns the distribution pattern used for this edge.
getDriver() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getDriverClass() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
getDriverComparator(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getDriverComparator(int) - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getDriverComparator(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getDriverStrategy() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getDuration() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getDuration() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getDynamicConfiguration() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the dynamic configuration.
getDynamicProperties() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
getElementsCollectedAndReset() - 类 中的方法org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
getElementSerializer() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
getElementSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
getEndKeyGroup() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
getEndOffsetExclusive() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
getEndpointId() - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherFactory
 
getEndpointId() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
 
getEndpointId() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Returns the rpc endpoint's identifier.
getEndTime() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getEndTime() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the time stamp, when all stack traces were collected at the JobManager.
getEndTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getEndTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getEndTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getEndTimestamp() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the time stamp, when all stack traces were collected at the JobManager.
getEndTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
getEndToEndDuration() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the end to end duration until the checkpoint failure.
getEndToEndDuration(long) - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Computes the duration since the given trigger timestamp.
getEndToEndDuration(long) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the duration of completed checkpoints.
getEntryIterator() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getEntryIterator() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getEntryIterator() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Returns an iterator that can be used to iterate over all the elements in the table.
getEnvironment() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the environment of this task.
getEnvironmentVariables() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the environment variables.
getError(ClassLoader) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets the attached exception, which is in serialized form.
getErrorDelayMillis() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
getEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getException() - 类 中的方法org.apache.flink.runtime.executiongraph.ErrorInfo
Returns the serialized form of the original exception.
getExceptionAsString() - 类 中的方法org.apache.flink.runtime.executiongraph.ErrorInfo
Returns the contained exception as a string.
getExecutingThread() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getExecutionAttemptID() - 类 中的方法org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getExecutionAttemptId() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getExecutionAttemptID() - 类 中的方法org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getExecutionConfig() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the job specific ExecutionConfig.
getExecutionConfig() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the global ExecutionConfig.
getExecutionConfig() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getExecutionConfig() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getExecutionConfig() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getExecutionConfigInfo() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo
 
getExecutionGraph() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getExecutionGraph(JobID) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getExecutionGraph(JobID, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
Gets the AccessExecutionGraph for the given JobID and caches it.
getExecutionId() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Gets the ID of the task execution attempt.
getExecutionId() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getExecutionId() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getExecutionState() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the current ExecutionState for this execution vertex.
getExecutionState() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getExecutionState() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getExecutionState() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getExecutionState() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Returns the current execution state of the task.
getExecutionState() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
Returns the new execution state of the task.
getExecutor() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getExecutor() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Gets the executor, provided by this RPC service.
getExpected() - 异常错误 中的方法org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getExtendedResources() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the extended resources.
getExternalPath() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
Returns the external pointer of this checkpoint.
getExternalPath() - 类 中的方法org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the external path if this checkpoint was persisted externally.
getExternalPath() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
getExternalPath() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
getExternalPointer() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getExternalPointer() - 接口 中的方法org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
Gets the external pointer to the checkpoint.
getExternalPointer() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
 
getFailedCheckpointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getFailoverRegion(ExecutionVertex) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Finds the failover region that contains the given execution vertex.
getFailoverStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the failover strategy used by the execution graph to recover from failures of tasks.
getFailureCause() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureCause() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getFailureCause() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
 
getFailureCause() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
If the task has failed, this method gets the exception that caused this task to fail.
getFailureCauseAsString() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the exception that caused the job to fail.
getFailureCauseAsString() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the exception that caused the job to fail.
getFailureCauseAsString() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getFailureCauseAsString() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getFailureCauseAsString() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getFailureCauseAsString() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureInfo() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the exception that caused the job to fail.
getFailureInfo() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getFailureInfo() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureMessage() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the failure message or null if no cause was provided.
getFailureMessage() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
getFailureReason() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
getFailureTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the timestamp when this checkpoint failed.
getFailureTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
getFencingToken() - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
getFencingToken() - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
getFencingToken() - 接口 中的方法org.apache.flink.runtime.rpc.FencedRpcGateway
Get the current fencing token.
getFencingToken() - 接口 中的方法org.apache.flink.runtime.rpc.messages.FencedMessage
 
getFencingToken() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
getFencingToken() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
getField(TtlValue<T>, int) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
getFile(TransientBlobKey) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Retrieves the local path of a file associated with a job and a blob key.
getFile(JobID, PermanentBlobKey) - 类 中的方法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) - 类 中的方法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) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
getFile(JobID, TransientBlobKey) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
getFile(TransientBlobKey) - 接口 中的方法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) - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.rest.FileUpload
 
getFileChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getFilehandlesDriver() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getFilehandlesInput(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getFileInternal(JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.AbstractBlobCache
Returns local copy of the file for the BLOB with the given key.
getFileInternal(JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
getFilePath() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
Gets the path where this handle's state is stored.
getFileSystem() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
getFilterStrategy() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer
 
getFlinkConfig() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getFlinkRevision() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getFlinkVersion() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getFoldingState(FoldingStateDescriptor<T, ACC>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getForForwardExchange(ExecutionMode) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
 
getFormatDescription() - 类 中的方法org.apache.flink.runtime.jobgraph.InputFormatVertex
 
getFormatDescription() - 类 中的方法org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
getForShuffleOrBroadcast(ExecutionMode) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
 
getFQDNHostname() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the fully-qualified domain name the TaskManager.
getFreedMemory() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getFreeMemory() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getFreeMemory() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getFreeMemory() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
getFreeSlotForTask(ExecutionVertex, Iterable<TaskManagerLocation>, boolean) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Gets a suitable instance to schedule the vertex execution to.
getFullSegments() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
getFullSegments() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
 
getFuture() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistration
 
getFuture() - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
Get future of object to retrieve.
getFuture() - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
 
getFutureExecutor() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the ExecutionContext associated with this ExecutionGraph.
getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - 类 中的静态方法org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the garbage collection statistics from the JVM.
getGateway() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
getGateway() - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterService
Get the JobMasterGateway belonging to this service.
getGlobalAggregateManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getGlobalAggregateManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getGlobalAggregateManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getGlobalModVersion() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Gets the global modification version of the execution graph when this execution was created.
getGraph() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getGroupID() - 类 中的方法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.
getGroupId() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the ID that identifies the co-location group.
getGroupId() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
 
getGroupName(CharacterFilter) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
getGroupName(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
getGroupName(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
getGroupName(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
getGroupName(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
getGroupName(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
getGroupRangeOffsets() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getGroupSize(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getHadoopUser() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets the name of the user that is running the JVM.
getHadoopVersionString() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
 
getHandleName() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getHandlers() - 枚举 中的方法org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
 
getHandlers() - 接口 中的方法org.apache.flink.runtime.webmonitor.WebMonitorExtension
Gets the collection of extension handlers to register at the WebMonitorEndpoint.
getHardwareDescription() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getHardwareDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getHash() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
 
getHeadElementIndex() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
Returns the start index of the queue elements in the array.
getHeadElementIndex() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueue
 
getHeapMemoryInMB() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the heap memory needed in MB.
getHighAvailabilityServices() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getHistory() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted checkpoint history.
getHistory() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
getHost() - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getHost() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getHostname(RpcService) - 类 中的方法org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
 
getHostname() - 类 中的方法org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
 
getHostname() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Gets the hostname of the underlying RPC endpoint.
getHostname() - 接口 中的方法org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
getHostname() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the hostname of the TaskManager.
getHostname() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
 
getHttpMethod() - 接口 中的方法org.apache.flink.runtime.rest.handler.RestHandlerSpecification
Returns the HttpMethodWrapper to be used for the request.
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
已过时。
 
getHttpMethod() - 类 中的方法org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
已过时。
 
getHttpResponseStatus() - 异常错误 中的方法org.apache.flink.runtime.rest.handler.RestHandlerException
 
getHttpResponseStatus() - 异常错误 中的方法org.apache.flink.runtime.rest.util.RestClientException
 
getId() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getId() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getId() - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getId() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getID() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the ID of this job vertex.
getId() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Gets the ID that identifies this co-location group.
getId() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
getId() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getId() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getId() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.Metric
 
getId() - 类 中的方法org.apache.flink.runtime.rest.messages.queue.QueueStatus
 
getID() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
Returns the ID of the task this result belongs to
getIdAlternatives() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns a list of all alternative IDs of this job vertex.
getIdentifier() - 接口 中的方法org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Gets the identifier of this hook.
getIdlenessTimeout() - 类 中的方法org.apache.flink.runtime.rest.RestClientConfiguration
RestOptions.IDLENESS_TIMEOUT.
getIdleSince() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getImplicitConvergenceCriterion(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getImplicitConvergenceCriterionAggregatorName() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIndex() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
getIndex() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getIndexInSubtaskGroup() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the index of this subtask in the subtask group.
getInfoForCurrentThread() - 类 中的方法org.apache.flink.runtime.query.KvStateEntry
 
getInitialCredit() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getInitialRegistrationPause() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getInitialRegistrationTimeoutMillis() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
getInitialTableSize(int, int, int, int) - 类 中的静态方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getInput(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getInput(int) - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getInputChannelDeploymentDescriptor() - 类 中的方法org.apache.flink.runtime.executiongraph.PartitionInfo
 
getInputChannelDeploymentDescriptors() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getInputChannelId() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getInputComparator(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getInputDependencyConstraint() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getInputDependencyConstraint() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getInputDependencyConstraint() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getInputEdges(int) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getInputGate(int) - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getInputGate(int) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getInputGateById(IntermediateDataSetID) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getInputGates() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getInputLocalStrategy(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getInputNum() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getInputs() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getInputs() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getInputSerializer(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getInputSerializer(int) - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getInputSerializer(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getInputSplitData() - 类 中的方法org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
getInputSplitProvider() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the input split provider assigned to this environment.
getInputSplitProvider() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getInputSplitSource() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getInstalledContext() - 类 中的静态方法org.apache.flink.runtime.security.SecurityUtils
 
getInstalledModules() - 类 中的静态方法org.apache.flink.runtime.security.SecurityUtils
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.blob.VoidBlobWriter
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
Gets the singleton instance.
getInstance() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
Gets the singleton instance.
getInstance() - 类 中的静态方法org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
getInstance() - 异常错误 中的方法org.apache.flink.runtime.instance.InstanceDiedException
 
getInstance(ResourceID) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
getInstance() - 接口 中的方法org.apache.flink.runtime.plugable.DeserializationDelegate
 
getInstance() - 类 中的方法org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
getInstance() - 类 中的方法org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
getInstance() - 类 中的方法org.apache.flink.runtime.plugable.SerializationDelegate
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.EmptyMessageParameters
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.EmptyRequestBody
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.EmptyResponseBody
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
已过时。
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
已过时。
 
getInstance() - 类 中的静态方法org.apache.flink.runtime.util.clock.SystemClock
 
getInstanceId() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getInstanceId() - 类 中的方法org.apache.flink.runtime.messages.StackTrace
 
getInstanceID() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getInstanceId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getInstancesByHost() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getIntermediateDataSetID() - 类 中的方法org.apache.flink.runtime.executiongraph.PartitionInfo
 
getIntermediateResult() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getInternal() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalAppendingState
Get internally stored value.
getInternalIndex() - 接口 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
Returns the current index of this object in the internal array of HeapPriorityQueue.
getIntersection(KeyGroupRange) - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getIntersection(KeyGroupRange) - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getIntersection(KeyGroupRange) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
Create a range that represent the intersection between this range and the given range.
getIntersection(KeyGroupRange) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getInvokableClass(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the invokable class which represents the task of this vertex
getInvokableClassName() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getInvokableClassName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the name of the invokable class which represents the task of this vertex.
getIOManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the current IOManager.
getIOManager() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getIOManager() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getIOManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getIOManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getIOMetricGroup() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
Returns the OperatorIOMetricGroup for this operator.
getIOMetricGroup() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
Returns the TaskIOMetricGroup for this task.
getIOMetrics() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
 
getIOMetrics() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getIOMetrics() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getIOMetrics() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getIOMetrics() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
 
getIoMetricsInfo() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getIOWait() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getIsSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIsSolutionSetUpdateWithoutReprobe() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIsWorksetIteration() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIsWorksetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationAggregators() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
getIterationAggregators(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadFinalOutputConfig() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadIndexOfSyncOutput() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadPartialSolutionOrWorksetInputIndex() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadSolutionSetInputIndex() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationId() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getIterator() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - 接口 中的方法org.apache.flink.runtime.operators.sort.Sorter
 
getIterator() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getIterator() - 类 中的方法org.apache.flink.runtime.operators.TempBarrier
This method resets the input!
getIterator() - 接口 中的方法org.apache.flink.runtime.operators.util.CloseableInputProvider
Gets the iterator over this input.
getIterator() - 类 中的方法org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
 
getJob() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getJobAccumulators() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
getJobCheckpointingConfiguration() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Returns the job's checkpointing configuration which is derived from the CheckpointConfig.
getJobConfiguration() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the job-wide configuration object that was attached to the JobGraph.
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the configuration object for this job.
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the job configuration object which was attached to the original JobGraph.
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobConfiguration() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getJobExecutionResult() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
getJobGraph() - 类 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the submitted JobGraph.
getJobGraph() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getJobID() - 类 中的方法org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getJobId() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getJobId() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getJobID() - 异常错误 中的方法org.apache.flink.runtime.client.JobExecutionException
 
getJobId() - 类 中的方法org.apache.flink.runtime.client.JobStatusMessage
 
getJobId() - 类 中的方法org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getJobId() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getJobId() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's job ID.
getJobID() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the ID of the job that the task belongs to.
getJobID() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the JobID for this execution graph.
getJobID() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobID() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobId() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobId() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobId() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getJobId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getJobID() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the ID of the job.
getJobId() - 类 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobID of the submitted JobGraph.
getJobId() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotReport
 
getJobId() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
 
getJobId() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getJobId() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
getJobId() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the JobID the KvState instances belong to.
getJobId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Returns the JobID the KvState instance belongs to.
getJobId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobID the KvState instance belongs to.
getJobId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobID the KvState instance belongs to.
getJobID() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getJobId() - 类 中的方法org.apache.flink.runtime.resourcemanager.SlotRequest
Get the JobID of the slot requested for.
getJobId() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJobId() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo
 
getJobId() - 异常错误 中的方法org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
getJobID() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobId() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getJobID() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
Get the job id of the slot allocated for.
getJobID() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobID() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getJobID() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
The ID of the job the task belongs to
getJobIds() - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
getJobIds() - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
getJobIds() - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Get all job ids of submitted job graphs to the submitted job graph store.
getJobIds() - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
getJobInformationOrBlobKey() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobLeaderIdService() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
getJobLeaderService() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobManager() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
已过时。
Use semantically equivalent MetricStore.getJobManagerMetricStore().
getJobManagerAddress(Configuration) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
Returns the JobManager's hostname and port extracted from the given Configuration.
getJobManagerBindAddress() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getJobManagerFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getJobManagerGateway() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobManagerGateway() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobManagerJobFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getJobManagerLeaderElectionService(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the given job.
getJobManagerLeaderElectionService(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderElectionService(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderElectionService(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerLeaderRetriever(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
已过时。
This method should only be used by the legacy code where the JobManager acts as the master.
getJobManagerLeaderRetriever(JobID, String) - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader retriever for the job JobMaster which is responsible for the given job
getJobManagerLeaderRetriever(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderRetriever(JobID, String) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderRetriever(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderRetriever(JobID, String) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderRetriever(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerLeaderRetriever(JobID, String) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerManagedKeyedState() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the JobManager.
getJobManagerMode() - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getJobManagerOwnedSnapshot() - 类 中的方法org.apache.flink.runtime.state.SnapshotResult
 
getJobManagerRawKeyedState() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobManagerTable() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobMasterId() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobMasterId() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobMasterMainThreadExecutor() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobMetricStore(String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the given job ID.
getJobName() - 类 中的方法org.apache.flink.runtime.client.JobStatusMessage
 
getJobName() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job name for the execution graph.
getJobName() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobName() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobName() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getJobName() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getJobName() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo
 
getJobs() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
getJobs() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
getJobSchedulingStatus(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.RunningJobsRegistry
Gets the scheduling status of a job.
getJobSchedulingStatus(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
getJobState() - 类 中的方法org.apache.flink.runtime.client.JobStatusMessage
 
getJobStatus() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
getJobStatus(JobID) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getJobStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJobsWithStatus() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
getJobTerminationFuture() - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
 
getJobTimeout() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
getJobVertex(JobVertexID) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job vertex for the given JobVertexID.
getJobVertex(JobVertexID) - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobVertex(JobVertexID) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobVertex() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobVertex() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexID() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ID of the operator the statistics belong to.
getJobVertexId() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Gets the ID of the JobVertex for which this task executes a parallel subtask.
getJobVertexId() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the JobVertexID for this job vertex.
getJobVertexId() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobvertexId() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the JobVertexID the KvState instances belong to.
getJobVertexId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobVertexID the KvState instance belongs to.
getJobVertexId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobVertexID the KvState instance belongs to.
getJobVertexID() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobVertexId() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getJobVertexIds() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getJobVertexInfos() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJobVertexMetrics() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getJobVerticesPerState() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJson() - 类 中的方法org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
getJsonPlan() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job plan as a JSON string.
getJsonPlan() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJsonPlan() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJsonPlan() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJsonPlan() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo
 
getJvmStartupOptions() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets the system parameters and environment parameters that were passed to the JVM on startup.
getJvmStartupOptionsArray() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets the system parameters and environment parameters that were passed to the JVM on startup.
getJvmVersion() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets the version of the JVM in the form "VM_Name - Vendor - Spec/Version".
getKey() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
getKey() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Returns the key of this parameter, e.g.
getKey() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
getKey() - 接口 中的方法org.apache.flink.runtime.state.Keyed
Returns the key attribute.
getKey() - 接口 中的方法org.apache.flink.runtime.state.StateEntry
Returns the key of this entry.
getKey() - 类 中的方法org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
 
getKeyA(A) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
getKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
getKeyedStateHandles(Collection<? extends KeyedStateHandle>, KeyGroupRange) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Determine the subset of KeyGroupsStateHandles with correct key group index for the given subtask KeyGroupRange.
getKeyedStateStore() - 接口 中的方法org.apache.flink.runtime.state.ManagedInitializationContext
Returns an interface that allows for registering keyed state with the backend.
getKeyedStateStore() - 类 中的方法org.apache.flink.runtime.state.StateInitializationContextImpl
 
getKeyedStateStreamFuture() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getKeyGroupCompressionDecorator() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeyGroupId(int) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
getKeyGroupId(int) - 接口 中的方法org.apache.flink.runtime.state.KeyGroupsList
Returns the id of the keygroup at the given index, where index in interval [0, KeyGroupsList.getNumberOfKeyGroups()[.
getKeyGroupId() - 类 中的方法org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
Returns the key group that corresponds to the data in the provided stream.
getKeyGroupList() - 类 中的方法org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns a list of all key-groups which can be written to this stream.
getKeyGroupOffset(int) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
Returns the offset for the given key-group.
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getKeyGroupRange() - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the key groups for this backend.
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getKeyGroupRange() - 接口 中的方法org.apache.flink.runtime.state.KeyedStateHandle
Returns the range of the key groups contained in the state.
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
getKeyGroupRange() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getKeyGroupWriter() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
Partitions the snapshot data by key-group.
getKeyGroupWriter() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
 
getKeyGroupWriter() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshot
This method returns StateSnapshot.StateKeyGroupWriter and should be called in the asynchronous part of the snapshot.
getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getKeys(String, N) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
getKeys(String, N) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
 
getKeySerializer() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
 
getKeySerializer() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeySerializer() - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
TypeSerializer for the state backend key type.
getKeySerializer() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of key this state is associated to.
getKeySerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
getKeySerializerSnapshot() - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getKeytab() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getKrb5LoginModuleName() - 类 中的静态方法org.apache.flink.runtime.security.KerberosUtils
 
getKvState(KvStateID) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Returns the KvStateEntry containing the requested instance as identified by the given KvStateID, along with its KvStateInfo or null if none is registered.
getKvStateID(int) - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the registered KvStateID for the key group index or null if none is registered yet.
getKvStateId() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the ID of the registered KvState instance.
getKvStateLocation(String) - 类 中的方法org.apache.flink.runtime.query.KvStateLocationRegistry
Returns the KvStateLocation for the registered KvState instance or null if no location information is available.
getKvStateLocationOracle(JobID) - 接口 中的方法org.apache.flink.runtime.query.KvStateClientProxy
Retrieves a future containing the currently leading key-value state location oracle.
getKvStateLocationRegistry() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getKvStateProxy() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateRegistry() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateServer() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateServerAddress(int) - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the registered server address for the key group index or null if none is registered yet.
getKvStateServerAddress() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the server address where to find the KvState instance.
getLast() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
Returns the last checkpoint ID (current - 1).
getLastAccessTimestamp() - 类 中的方法org.apache.flink.runtime.state.ttl.TtlValue
 
getLastHeartBeat() - 类 中的方法org.apache.flink.runtime.instance.Instance
Gets the timestamp of the last heartbeat.
getLastHeartbeat() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getLastHeartbeatFrom(ResourceID) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManager
Returns the last received heartbeat from the given target.
getLastHeartbeatFrom(ResourceID) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
getLastOutputCollector() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getLastTasksConfig() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getLastUpdateTime() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getLatestAcknowledgedSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAcknowledgedSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAckTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
getLatestAckTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
getLatestAckTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getLatestAckTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getLatestCheckpoint() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the latest CompletedCheckpoint instance or null if none was added.
getLatestCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getLatestCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getLatestCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
getLatestCompletedCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLatestFailedCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLatestPriorAllocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLatestPriorExecution() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLatestPriorLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location where the latest completed/canceled/failed execution of the vertex's task happened.
getLatestRestoredCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the latest restored checkpoint.
getLatestSavepoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLatestVersion(Collection<RestAPIVersion>) - 枚举 中的静态方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
Returns the latest version from the given collection.
getLeaderConnectionInfoFuture() - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
getLeaderFuture() - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
Returns the current JobManagerGateway future.
getLeaderGatewayFuture() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getLeaderId(JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
getLeaderID() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the current leader id assigned at the ResourceManager.
getLeaderNow() - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
Returns the current leader information if available.
getLeaderSessionID() - 类 中的方法org.apache.flink.runtime.akka.FlinkUntypedActor
Returns the current leader session ID associated with this actor.
getLeaderSessionID() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Returns the current leader session ID or null, if the contender is not the leader.
getLeaderSessionID() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
 
getLength() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getLength() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
getLength() - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
Returns the length of the operator chain.
getLength() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
getLibraryCacheManager() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getLibraryCacheManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelInputView
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessInputView
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the limit for reading bytes from the given memory segment.
getLimitForSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getListState(ListStateDescriptor<T>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getListState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getLocality() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getLocality() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
Gets the locality information attached to this slot.
getLocality() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the locality of this slot.
getLocality() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getLocality() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
getLocality() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
 
getLocalRecoveryConfig() - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
getLocalRecoveryConfig() - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
getLocalRecoveryConfig() - 接口 中的方法org.apache.flink.runtime.state.TaskLocalStateStore
Returns the LocalRecoveryConfig for this task local state store.
getLocalRecoveryConfig() - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
getLocalRecoveryStateRootDirectories() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getLocalStateDirectoryProvider() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryConfig
 
getLocation() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the location assigned to this slot.
getLocation() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
 
getLocationConstraint() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLocationConstraint(int) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
getLocationReference() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorageLocation
Gets a reference to the storage location.
getLocationReference() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getLocationReference() - 类 中的方法org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
 
getLocationReference() - 类 中的方法org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
 
getLockPath(String) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the path for the lock node relative to the given path.
getLogicalScope(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the logical scope of this group, for example "taskmanager.job.task".
getLogicalScope(CharacterFilter, char) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the logical scope of this group, for example "taskmanager.job.task".
getLogicalScope(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLogicalScope(CharacterFilter, char) - 类 中的方法org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLoginContextNames() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getMainThreadExecutor() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the executor which executes in the main thread of the ResourceManager
getMainThreadExecutor() - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
Returns a main thread executor which is bound to the currently valid fencing token.
getMainThreadExecutor() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Gets the main thread execution context.
getManagedKeyedState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the managed keyed state.
getManagedKeyedState() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect managedKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
getManagedOperatorState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the managed operator state.
getManagedOperatorState() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
getMapState(MapStateDescriptor<UK, UV>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getMasterHooks() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getMasterHookStates() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getMasterStates() - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Gets the checkpointed states generated by the master.
getMasterStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getMasterStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getMatchesFor(PT) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getMatchFor(PT, BT) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
getMatchFor(PT) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
getMatchFor(PT, T) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
getMatchFor(PT) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
getMatchFor(PT, T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
Searches the hash table for the record with the given key.
getMatchFor(PT) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
getMax() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getMax() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getMaxBackPressureRatio() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the maximum back pressure ratio of all sub tasks.
getMaxCapacity() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns the maximum size of the buffer, i.e. the capacity of the underlying MemorySegment.
getMaxCapacity() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
getMaxCapacity() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getMaxCapacity() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getMaxCheckpointStatisticCacheEntries() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getMaxConcurrentCheckpoints() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getMaxContentLength() - 类 中的方法org.apache.flink.runtime.rest.RestClientConfiguration
Returns the max content length that the REST client endpoint could handle.
getMaxContentLength() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the max content length that the REST server endpoint could handle.
getMaxDepth(int) - 类 中的静态方法org.apache.flink.runtime.operators.sort.QuickSort
Deepest recursion before giving up and doing a heapsort.
getMaximum() - 类 中的方法org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the maximum seen value.
getMaximum() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
getMaximumFramesize() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
getMaximumParallelism() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Gets the maximum parallelism of all operations in this job graph.
getMaxJvmHeapMemory() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
The maximum JVM heap size, in bytes.
getMaxNumberOfMemorySegments() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the maximum number of memory segments this buffer pool should use.
getMaxNumberOfRetainedCheckpoints() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the max number of retained checkpoints.
getMaxNumberOfRetainedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getMaxNumberOfRetainedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getMaxNumberOfSubtaks() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getMaxNumThreads() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getMaxParallelism() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the max parallelism for this job vertex.
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getMaxParallelism() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Gets the maximum parallelism for the task.
getMaxRegistrationDuration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxRegistrationPause() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxRegistrationTimeoutMillis() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
getMaxStateSize() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
Gets the size (in bytes) that a individual chunk of state may have at most.
getMaxStateSize() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getMemoryFraction() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getMemoryInMB() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the total memory needed in MB.
getMemoryManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the current MemoryManager.
getMemoryManager() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getMemoryManager() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getMemoryManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getMemoryManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getMemoryPoolStatsAsString(List<MemoryPoolMXBean>) - 类 中的静态方法org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the memory pool statistics from the JVM.
getMemorySegment() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
已过时。
getMemorySegment() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getMemorySegment() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
Returns the underlying memory segment.
getMemorySegment() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
getMemorySegmentOffset() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
已过时。
getMemorySegmentOffset() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getMemorySegmentOffset() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getMemorySegmentSize() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns the size of the underlying memory segments.
getMemorySegmentSize() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getMemorySize() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Returns the total size of memory handled by this memory manager.
getMemoryType() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Gets the type of memory (heap / off-heap) managed by this memory manager.
getMemoryType() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns the memory type to use.
getMemoryUsageStatsAsString(MemoryMXBean) - 类 中的静态方法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>) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Returns an iterator that iterates over the merged result from all given channels.
getMessage() - 异常错误 中的方法org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getMessageHeaders() - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
getMetadataFilePath() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getMetadataHandle() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getMetadataHandle() - 接口 中的方法org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
Gets the state handle to the checkpoint's metadata.
getMetadataHandle() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
 
getMetaDataState() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getMetaInfo() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getMetaInfo() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
 
getMetaInfo() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
getMetaInfoSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
getMetaInfoSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
 
getMetaInfoSnapshot() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshot
Returns a snapshot of the state's meta data.
getMetaStateHandle() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getMethodName() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getMethodName() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getMethodName() - 接口 中的方法org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the method's name.
getMetric(String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
 
getMetric(String, String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
 
getMetricGroup() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the task specific metric group.
getMetricGroup() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getMetricGroup() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getMetricGroup() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getMetricGroup() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getMetricIdentifier(String) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getMetricIdentifier(String, CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getMetricIdentifier(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getMetricIdentifier(String, CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getMetricQueryServicePath() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Returns the path of the MetricQueryService or null, if none is started.
getMetricQueryServicePath() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
Returns the address under which the MetricQueryService is reachable.
getMetricQueryServicePath() - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getMetrics() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
 
getMetrics() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
 
getMetricStore() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
Get MetricStore which contains all currently fetched metrics.
getMetricStore() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
Returns the MetricStore containing all stored metrics.
getMetricStore() - 枚举 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
 
getMimeTypeForExtension(String) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.MimeTypes
Gets the MIME type for the file with the given extension.
getMimeTypeForFileName(String) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.MimeTypes
Gets the MIME type for the file with the given name, by extension.
getMin() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getMin() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getMinFileSizeThreshold() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the minimum seen value.
getMinimum() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
getMinNumThreads() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
 
getMinOffloadingSize() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Returns the configuration used by the BLOB server.
getMinOffloadingSize() - 接口 中的方法org.apache.flink.runtime.blob.BlobWriter
Returns the min size before data will be offloaded to the BLOB store.
getMinOffloadingSize() - 类 中的方法org.apache.flink.runtime.blob.VoidBlobWriter
 
getMinParallelism() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
getMinPauseBetweenCheckpoints() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getMinResources() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Gets the minimum resource for the task.
getMultipartFileUploads(ChannelHandlerContext) - 类 中的静态方法org.apache.flink.runtime.rest.FileUploadHandler
 
getMutableObjectMode() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getName() - 类 中的方法org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getName() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getName() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the name for this job vertex.
getName() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getName() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the name assigned to the job graph.
getName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the name of the vertex.
getName() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouterHandler
 
getName() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getName() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getName() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
getName() - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getName() - 类 中的方法org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
 
getNamespace() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
getNamespace() - 接口 中的方法org.apache.flink.runtime.state.StateEntry
Returns the namespace of this entry.
getNamespace() - 类 中的方法org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
 
getNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
 
getNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
getNamespaceSerializer() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of namespace this state is associated to.
getNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getNativeMemoryInMB() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the native memory needed in MB.
getNestedSerializers(ArrayListSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializerSnapshot
 
getNestedSerializers(TtlStateFactory.TtlSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
 
getNetRuntime() - 类 中的方法org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getNetRuntime(TimeUnit) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
 
getNettyHttpMethod() - 枚举 中的方法org.apache.flink.runtime.rest.HttpMethodWrapper
 
getNetworkBufferPool() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getNetworkConfig() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNetworkEnvironment() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getNetworkInterfaceNames() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getNetworkMemoryInMB() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Returns a new inMemoryPartition object.
getNewInMemoryPartition(int, int) - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
getNewSlotForSharingGroup(ExecutionVertex, Iterable<TaskManagerLocation>, SlotSharingGroupAssignment, CoLocationConstraint, boolean) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Tries to allocate a new slot for a vertex that is part of a slot sharing group.
getNextBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getNextBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Returns the next Buffer instance of this queue iterator.
getNextBufferOrEvent() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
Blocking call waiting for next BufferOrEvent.
getNextBufferOrEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNextBufferOrEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getNextInputSplit(ClassLoader) - 接口 中的方法org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
Requests the next input split to be consumed by the calling task.
getNextInputSplit(ClassLoader) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
 
getNextInputSplit(ClassLoader) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
getNextPathNum() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
 
getNextRecord(T) - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
getNextRecord(T) - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
getNextReturnedBlock() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Gets the next memory segment that has been filled with data by the reader.
getNextReturnedBlock() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Gets the next memory segment that has been written and is available again.
getNextReturnedBlock() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
Gets the next memory segment that has been filled with data by the reader.
getNextReturnedBlock() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
Gets the next memory segment that has been written and is available again.
getNioBuffer(int, int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Gets a new ByteBuffer instance wrapping this buffer's bytes.
getNioBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getNioBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getNioBufferReadable() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Gets a new ByteBuffer instance wrapping this buffer's readable bytes, i.e. between Buffer.getReaderIndex() and Buffer.getSize().
getNioBufferReadable() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getNioBufferReadable() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getNioFileChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getNioFileChannel() - 接口 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.RightOuterJoinDriver
 
getNow() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getNow() - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
Returns the currently retrieved gateway if there is such an object.
getNumAckSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getNumAckSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getNumberAvailableSlots() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getNumberCollectedStates() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getNumberCollectedStates() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getNumberCompletedCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getNumberCPUCores() - 类 中的静态方法org.apache.flink.runtime.util.Hardware
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
getNumberFailedCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getNumberFreeSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceOverview
 
getNumberFreeSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberFreeSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getNumberFreeSlotsOf(InstanceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberInProgressCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getNumberLeaves() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getNumberLeaves() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getNumberLeaves() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the number of simple slots that are at the leaves of the tree of slots.
getNumberOfAcknowledgedSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the number of acknowledged subtasks.
getNumberOfAcknowledgedSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the number of acknowledged subtasks.
getNumberOfAcknowledgedTasks() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getNumberOfActiveConnections() - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
 
getNumberOfActiveConnections() - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
getNumberOfActiveConnections() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
getNumberOfAllocatedBytes() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
Returns the number of currently allocated bytes.
getNumberOfAllocatedSlots() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getNumberOfArenas() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getNumberOfAssignedPartitions() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getNumberOfAvailableBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getNumberOfAvailableInstances() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfAvailableMemorySegments() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number memory segments, which are currently held by this buffer pool.
getNumberOfAvailableMemorySegments() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getNumberOfAvailableSlots() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getNumberOfAvailableSlots() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getNumberOfAvailableSlots() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
NOTE: In the presence of multi-threaded operations, this number may be inexact.
getNumberOfAvailableSlotsForGroup(AbstractID) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfCompletedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of completed checkpoints.
getNumberOfCPUCores() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
Returns the number of CPU cores available to the JVM on the compute node.
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
getNumberOfDriverComparators() - 接口 中的方法org.apache.flink.runtime.operators.Driver
Gets the number of comparators required for this driver.
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
getNumberOfDriverComparators() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
getNumberOfEventsUntilInterruptInIterativeBroadcastGate(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfEventsUntilInterruptInIterativeGate(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfExecutionJobVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of job vertices currently held by this execution graph.
getNumberOfFailedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of failed checkpoints.
getNumberOfFullRestarts() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of full restarts that the execution graph went through.
getNumberOfInProgressCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of in progress checkpoints.
getNumberOfInputChannels() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getNumberOfInputChannels() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNumberOfInputChannels() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
Returns the total number of input channels across all unioned input gates.
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the number of inputs.
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
getNumberOfInputs() - 接口 中的方法org.apache.flink.runtime.operators.Driver
Gets the number of inputs that the task has.
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
getNumberOfInputs() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
getNumberOfInstancesWithAvailableSlots() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfIterations() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfKeyGroups() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getNumberOfKeyGroups() - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the number of key-groups aka max parallelism.
getNumberOfKeyGroups() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
getNumberOfKeyGroups() - 接口 中的方法org.apache.flink.runtime.state.KeyGroupsList
Returns the number of key group ids in the list.
getNumberOfLocalizedAssignments() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfNonAcknowledgedTasks() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getNumberOfNonLocalizedAssignments() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfOutstandingRequests() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
getNumberOfOutstandingRequests() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
Returns the number of outstanding requests.
getNumberOfPartitions() - 类 中的方法org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
 
getNumberOfPendingCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfProducedIntermediateDataSets() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Returns the number of produced intermediate data sets.
getNumberOfQueuedBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Gets the current number of received buffers which have not been processed yet.
getNumberOfQueuedBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNumberOfQueuedBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumberOfReferenceHolders(JobID) - 类 中的方法org.apache.flink.runtime.blob.PermanentBlobCache
 
getNumberOfRegisteredBufferPools() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getNumberOfRegisteredMasterHooks() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Gets the number of currently register master hooks.
getNumberOfRegisteredTaskManagers() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getNumberOfRegisteredTaskManagers() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
getNumberOfRegisteredTaskManagers() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Gets the currently registered number of TaskManagers.
getNumberOfRequiredBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getNumberOfRequiredMemorySegments() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number of guaranteed (minimum number of) memory segments of this buffer pool.
getNumberOfRestoredCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of restored checkpoints.
getNumberOfRetainedCheckpoints() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the current number of retained checkpoints.
getNumberOfRetainedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getNumberOfRetainedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getNumberOfRetainedSuccessfulCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfSlots() - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets the number of slots that are currently governed by this assignment group.
getNumberOfSlots() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getNumberOfSlots() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNumberOfSpillingDirectories() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the number of directories across which the I/O manager rotates its files.
getNumberOfSubpartitions() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getNumberOfSubpartitions() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getNumberOfSubpartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumberOfSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total number of subtasks involved in this checkpoint.
getNumberOfSubtasks() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the number of subtasks.
getNumberOfSubtasks() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getNumberOfSubTasks() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the number of sub tasks.
getNumberOfUnconstrainedAssignments() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfVariablesWithReferences() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
getNumberOfVertices() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the number of all vertices.
getNumberPendingTaskManagerSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceOverview
 
getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getNumberRegisteredSlotsOf(InstanceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberReporters() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Returns the number of registered reporters.
getNumberReporters() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getNumberReporters() - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getNumberRequiredTaskManagerSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
getNumberRestoredCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getNumberSlots() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getNumberSlots() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getNumberTaskManagers() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceOverview
 
getNumBroadcastInputs() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumBuffers() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the current size of this buffer pool.
getNumBuffersInLocalCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBuffersInRemoteCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBuffersOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInLocal() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInLocalPerSecond() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalRateMeter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemote() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemotePerSecond() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteRateMeter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInTotal() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOut() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesOutPerSecond() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutRateMeter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumFuturesCompleted() - 类 中的方法org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the number of Futures in the conjunction that are already complete.
getNumFuturesTotal() - 类 中的方法org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the total number of Futures in the conjunction.
getNumInputs() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
getNumInputs() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumJobsCancelled() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsFailed() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsFinished() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsRunningOrPending() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumKeyGroups() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the number of key groups of the operator the KvState instances belong to.
getNumOccupiedMemorySegments() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getNumRecordsIn() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsInCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsInPerSecond() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInRateMeter() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOut() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsOutPerSecond() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutRate() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRegisteredKeyGroups() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the current number of registered key groups.
getNumRequiredComparators() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
getNumSlotsAvailable() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
getNumSlotsTotal() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
getNumSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getNumSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getNumTargetKeyGroups() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getNumTargetKeyGroups() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumTaskInputs() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationHeadTask
 
getNumTaskInputs() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getNumTaskManagers() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getNumTaskManagersConnected() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
getNumTasks() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getNumWriteBehindBuffers(int) - 类 中的静态方法org.apache.flink.runtime.operators.hash.MutableHashTable
Determines the number of buffers to be used for asynchronous write behind.
getOccupancy() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Gets the number of bytes currently occupied in this hash table.
getOccupancy() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getOccupancy() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the number of bytes currently occupied in this sorter, records and sort index.
getOccupancy() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getOffsetForKeyGroup(int) - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getOffsets() - 类 中的方法org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
getOpenFileHandlesLimit() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Tries to retrieve the maximum number of open file handles.
getOperationKey(HandlerRequest<EmptyRequestBody, M>) - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
 
getOperationKey(HandlerRequest<EmptyRequestBody, SavepointDisposalStatusMessageParameters>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
 
getOperationKey(HandlerRequest<EmptyRequestBody, SavepointStatusMessageParameters>) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
getOperatorBackPressureStats(ExecutionJobVertex) - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Returns back pressure statistics for a operator.
getOperatorBackPressureStats(ExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Returns back pressure statistics for a operator.
getOperatorBackPressureStats() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
 
getOperatorDescription() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getOperatorID() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getOperatorId() - 类 中的方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
getOperatorIDs() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the IDs of all operators contained in this execution job vertex.
getOperatorIDs() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorLevelCachingDescription() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Gets the operator-level caching description for this input.
getOperatorName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorPrettyName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorsMemoryInMB() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the memory the operators needed in MB.
getOperatorState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
已过时。
This was deprecated as part of a refinement to the function names. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getOperatorStateMetaInfoSnapshots() - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getOperatorStates() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getOperatorStates() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getOperatorStates() - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the snapshotted operator states.
getOperatorStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getOperatorStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getOperatorStateStore() - 接口 中的方法org.apache.flink.runtime.state.ManagedInitializationContext
Returns an interface that allows for registering operator state with the backend.
getOperatorStateStore() - 类 中的方法org.apache.flink.runtime.state.StateInitializationContextImpl
 
getOperatorStateStreamFuture() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getOption(String) - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getOption(StateMetaInfoSnapshot.CommonOptionsKeys) - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getOptions() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
 
getOptions() - 类 中的方法org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
 
getOptions() - 接口 中的方法org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
Returns all relevant Options for parsing the command line arguments.
getOptionsImmutable() - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getOrAddOperator(String) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
getOrAddOperator(OperatorID, String) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
getOrAddOperator(OperatorID, String) - 类 中的方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
Creates or retrieves a keyed state backed by this state backend.
getOutputCollector() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Creates the Collector for the given task, as described by the given configuration.
getOutputCollector() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getOutputCollector() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getOutputComparator(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputDataDistribution(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputPartitioner(int, ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputSerializer(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputShipStrategy(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getOversizedRecordCount() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
Gets the number of oversized records handled by this combiner.
getOwner() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the owner of this slot.
getOwningJob(AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Returns the owning job of the TaskSlot identified by the given AllocationID.
getOwningTaskName() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getOwningTaskName() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getOwningTaskName() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getOwningTaskName() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getPackages() - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
getPageSize() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getPageSize() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getPageSize() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getPageSize() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Gets the size of the pages handled by the memory manager.
getPairComparatorFactory(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getParallelism() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getParallelism() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getParallelism() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the parallelism for this job vertex.
getParallelism() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getParallelism() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getParallelism() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Gets the parallelism of the task.
getParallelism() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getParallelismFactor() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
 
getParallelSubtaskIndex() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the subtask index of this execution.
getParallelSubtaskIndex() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the subtask index of this execution vertex.
getParallelSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getParallelSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getParallelSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getParallelSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getParameterTypes() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getParameterTypes() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getParameterTypes() - 接口 中的方法org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the method's parameter types
getParent() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the parent slot of this slot.
getPartitionById(IntermediateResultPartitionID) - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
Returns the partition with the given ID.
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - 类 中的方法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, ?>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
Creates or retrieves a partitioned state backed by this state backend.
getPartitionId() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getPartitionId() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getPartitionId() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
getPartitionId() - 异常错误 中的方法org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
getPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
getPartitioningFanOutNoEstimates(int) - 类 中的静态方法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() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getPartitionNumber() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
Gets the partition number of this partition.
getPartitionNumber() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
Gets the partition number of this partition.
getPartitionRequestInitialBackoff() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitionRequestMaxBackoff() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitions() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getPartitionStateChecker() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getPartitionStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
getPartitionType() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getPartitionType() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the type of this result partition.
getPath() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
Returns the path to the underlying temporary file.
getPath() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
getPath() - 类 中的方法org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
getPathFile() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
Returns the path to the underlying temporary file as a File.
getPathForJob(JobID) - 类 中的静态方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Returns the JobID as a String (with leading slash).
getPathParameter(Class<PP>) - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
Returns the value of the MessagePathParameter for the given class.
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.EmptyMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
 
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameters
Returns the collection of MessagePathParameter that the request supports.
getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
getPaths() - 接口 中的方法org.apache.flink.runtime.rest.handler.WebHandler
Returns an array of REST URL's under which this handler can be registered.
getPayload() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getPayload() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getPayload() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Returns the set payload or null if none.
getPayload() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getPayload() - 接口 中的方法org.apache.flink.runtime.rpc.messages.FencedMessage
 
getPayload() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
getPayload() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
getPayload() - 类 中的方法org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
getPendingCheckpoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
getPendingCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getPermanentBlobService() - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
 
getPermanentBlobService() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
getPermanentBlobService() - 接口 中的方法org.apache.flink.runtime.blob.BlobService
Returns a BLOB service for accessing permanent BLOBs.
getPhysicalSlotNumber() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getPhysicalSlotNumber() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getPhysicalSlotNumber() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlotContext
 
getPhysicalSlotNumber() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the slot number on the TaskManager.
getPhysicalSlotNumber() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotInfo
Gets the number of the slot.
getPhysicalSlotNumber() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getPipelineBreakingExchange(ExecutionMode) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
 
getPort() - 类 中的方法org.apache.flink.runtime.blob.AbstractBlobCache
Returns the port the BLOB server is listening on.
getPort() - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
 
getPort() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Returns the port on which the server is listening.
getPort() - 接口 中的方法org.apache.flink.runtime.blob.BlobService
Returns the port of the BLOB server that this BLOB service is working with.
getPort() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getPort() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Return the port under which the rpc service is reachable.
getPort() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
 
getPos() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
getPos() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
getPos() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
getPos() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
getPos() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
getPosition() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getPreferredAllocations() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the desired allocation ids for the slot.
getPreferredLocations() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the preferred locations for the slot.
getPreferredLocations() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the overall preferred execution location for this vertex's current execution.
getPreferredLocationsBasedOnInputs() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Gets the preferred resource for the task.
getPreProcessingOperationName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Gets the name of the pro-processing operation for this input.
getPreviousElementSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
getPreviousExecutionGraphAllocations() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a set of all previous allocation ids from the execution graph.
getPreviousGlobalAggregate(String) - 类 中的方法org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getPreviousKeySerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
getPreviousNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getPreviousPartitionStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
getPreviousStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getPreviousValueSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
getPrincipal() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getPriorExecutionAttempt(int) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the execution for the given attempt number.
getPriorExecutionAttempt(int) - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getPriorExecutionAttempt(int) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getPrioritizedManagedKeyedState() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
 
getPrivateState() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
getProbeSideBlockCount() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getProbeSideChannel() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getProbeSideComparator() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
getProbeSideRecordCount() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
getProcessorsCount() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getProducedDataSets() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getProducedDataSets() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getProducedPartitions() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getProducedPartitions() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getProducedPartitions() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getProducer() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getProducer() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getProducer() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getProducerId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
getProperties() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the properties of this checkpoint.
getProperties() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getProperties() - 类 中的方法org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the properties of the restored checkpoint.
getProxyPortRange() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the port range where the queryable state client proxy can listen.
getPushChainDriverClass() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
getQuantile(double) - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getQueryableStateConfig() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getQueryParameter(Class<QP>) - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
Returns the value of the MessageQueryParameter for the given class.
getQueryParameter(HandlerRequest<R, M>, Class<P>) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.EmptyMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
 
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameters
Returns the collection of MessageQueryParameter that the request supports.
getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
getQueryService() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getQueryServiceMessageSizeLimit() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getQueryServiceMetricInfo(CharacterFilter) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the metric query service scope for this group.
getRatio() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
getRawKeyedOperatorStateOutput() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotContext
Returns an output stream for keyed state
getRawKeyedOperatorStateOutput() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getRawKeyedState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the raw keyed state.
getRawKeyedState() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
getRawKeyedStateHandles(OperatorState, KeyGroupRange) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect rawKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
getRawKeyedStateInputs() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.state.StateInitializationContextImpl
 
getRawOperatorState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the raw operator state.
getRawOperatorState() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
getRawOperatorStateInputs() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.state.StateInitializationContextImpl
 
getRawOperatorStateOutput() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotContext
Returns an output stream for operator state
getRawOperatorStateOutput() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getReadEndAfterSuperstepEnded() - 类 中的方法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) - 类 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
Returns a reader for StateMetaInfoSnapshot with the requested state type and version number.
getReaderIndex() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns the reader index of this buffer.
getReaderIndex() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getReaderIndex() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, AbstractInvokable, TypeSerializer<E>, long) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Creates the reading thread.
getReadPosition() - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessInputView
 
getReason() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
Gets the reason why the checkpoint was declined.
getReason() - 类 中的方法org.apache.flink.runtime.registration.RegistrationResponse.Decline
Gets the reason for the rejection.
getReceiveRatePerInterface(int) - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getReceiverId() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getRecord(int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getRecord(T, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getRecord(int) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the record at the given logical position.
getRecord(T, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the record at the given logical position.
getRecord(int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getRecord(T, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getRecordCount() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
number of records in partition including garbage
getRecordsRead() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
getRecordsWritten() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
getRecoveryMode(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
Gets the recovery mode as configured, based on HighAvailabilityOptions.HA_MODE.
getRecursionLevel() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
Gets this partition's recursion level.
getRecycler() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Gets the buffer's recycler.
getRecycler() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getRecycler() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getRedirectResponse(String, String, HttpResponseStatus) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getReducingState(ReducingStateDescriptor<T>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getReference() - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getReferenceBytes() - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
Gets the reference bytes.
getReferenceCount() - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getRefreshInterval() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getRefreshInterval() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getRefusedDelayMillis() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
getRefusedRegistrationPause() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getRegisteredBroadcastStateNames() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getRegisteredExecutions() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRegisteredInstance(ResourceID) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredInstanceById(InstanceID) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredStateNames() - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getRegistrationId() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the ID that the ResourceManager assigned the registration.
getRegistrationName() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Returns the name under which the KvState instances have been registered.
getRegistrationName() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Returns the name under which the KvState has been registered.
getRegistrationName() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the name under which the KvState has been registered.
getRegistrationName() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the name under which the KvState has been registered.
getRelativeBackChannelMemory() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeInputMaterializationMemory(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeMemoryDriver() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeMemoryInput(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeSolutionSetMemory() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getReleaseFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Gets the release future which is completed once the execution reaches a terminal state and the assigned resource has been released.
getReporterConfigurations() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getReporters() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getRequest() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
getRequestBody() - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
Returns the request body.
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getRequestClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
 
getRequestClass() - 接口 中的方法org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
Returns the class of the request message.
getRequestFuture() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getRequiredClasspaths() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of classpaths referring to the directories/JAR files required to run this job.
getRequiredClasspaths() - 类 中的方法org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getRequiredClasspathURLs() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredJarFileBlobKeys() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredJarFiles() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of BLOB keys referring to the JAR files required to run this job.
getRequiredJarFiles() - 类 中的方法org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getResolvedRootSlot(SlotInfo) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
getResolvedRootSlots() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
Returns a collection of all resolved root slots.
getResourceID() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
getResourceID() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceID
A ResourceID can always retrieve a ResourceID.
getResourceID() - 接口 中的方法org.apache.flink.runtime.clusterframework.types.ResourceIDRetrievable
Gets the ResourceID of the object.
getResourceID() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
 
getResourceID() - 类 中的方法org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
getResourceID() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getResourceId() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getResourceID() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResourceID() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
getResourceID() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the ID of the resource in which the TaskManager is started.
getResourceIdString() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceID
Gets the Resource Id as string.
getResourceManagerId() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
getResourceManagerId() - 类 中的方法org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
getResourceManagerId() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the unique ID that identifies the ResourceManager.
getResourceManagerLeaderElectionService() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the cluster's resource manager.
getResourceManagerLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getResourceManagerLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getResourceManagerLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getResourceManagerLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader retriever for the cluster's resource manager.
getResourceManagerLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getResourceManagerLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getResourceManagerLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getResourceManagerResourceId() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the desired resource profile for the slot.
getResourceProfile() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlotContext
 
getResourceProfile() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotInfo
Returns the resource profile of the slot.
getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.SlotRequest
Get the resource profile of the desired slot
getResourceProfile() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getResourceProfile() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
Get the resource profile of this slot.
getResources() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getResponse(HttpResponseStatus, String) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getResponseClass() - 接口 中的方法org.apache.flink.runtime.rest.messages.MessageHeaders
Returns the class of the response message.
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getResponseClass() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getResponseHeaders() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Response headers that should be added to every HTTP response.
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getResponseStatusCode() - 接口 中的方法org.apache.flink.runtime.rest.messages.MessageHeaders
Returns the http status code for the response.
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getResponseStatusCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getResponseTypeParameters() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
 
getResponseTypeParameters() - 接口 中的方法org.apache.flink.runtime.rest.messages.MessageHeaders
Returns the collection of type parameters for the response type.
getRestAddress() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
getRestAddress() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
 
getRestAddress() - 接口 中的方法org.apache.flink.runtime.webmonitor.WebMonitor
Returns the REST address of this WebMonitor.
getRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRestartStrategyFactory() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getRestBaseUrl() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
Returns the base URL of the REST server endpoint.
getRestBindAddress() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the address that the REST server endpoint should bind itself to.
getRestBindPortRange() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the port range that the REST server endpoint should listen on.
getRestoreCheckpointId() - 类 中的方法org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
 
getRestoredCheckpointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getRestorePath() - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns the path to the savepoint to restore from.
getRestoreTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the timestamp when the checkpoint was restored.
getRestoreTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
getRestPort() - 类 中的方法org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
 
getResultFuture() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getResultId() - 类 中的方法org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
getResultId() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getResultOptimizerProperties() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getResultPartitionConsumableNotifier() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResultPartitionManager() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getResultType() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
getResultType() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getResultType() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getRetryingRegistrationConfiguration() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getRetryingRegistrationConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getRetryingRegistrationConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getReturnQueue() - 类 中的方法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() - 类 中的方法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() - 接口 中的方法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() - 接口 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.RightOuterJoinDriver
 
getRevisionInformation() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Returns the code revision (commit and commit date) of Flink, as generated by the Maven builds.
getRoot() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the root slot of the tree containing this slot.
getRootSlotNumber() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the number of the root slot.
getRouteResult() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
getRpcGateway() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
getRPCPortRange(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
Returns the port range for the common RpcService.
getRpcService() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Gets the endpoint's RPC service.
getRpcServiceSharing() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getRpcTimeout() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getRpcTimeout() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, Configuration) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, AkkaRpcServiceUtils.AkkaProtocol) - 类 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRunnable() - 类 中的方法org.apache.flink.runtime.rpc.messages.RunAsync
 
getRunningJobsRegistry() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the registry that holds information about whether jobs are currently running.
getRunningJobsRegistry() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getRunningJobsRegistry() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getSampleId() - 类 中的方法org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSampleId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the ID of the sample.
getSampleId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the ID of the sample.
getSamples() - 类 中的方法org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSavepointPath() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
 
getSavepointPath() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the configured savepoint restore setting.
getSavepointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getScheduledExecutor() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getScheduledExecutor() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Gets a scheduled executor from the RPC service.
getScheduledExecutorService() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getScheduleMode() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getScheduleMode() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
getScopeComponents() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getScopeFormats() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Returns the scope formats.
getScopeFormats() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getScopeFormats() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getScopeFormats() - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getSecondaryStreamException() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
getSecurityConfig() - 类 中的方法org.apache.flink.runtime.security.modules.HadoopModule
 
getSecurityModuleFactories() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getSegmentsForReaders(List<List<MemorySegment>>, List<MemorySegment>, int) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Divides the given collection of memory buffers among numChannels sublists.
getSegmentSize() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the size of the segments used by this view.
getSelfGateway(Class<C>) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getSenderBacklog() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getSendRatePerInterface(int) - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
getSequenceNumber() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getSerializableListState(String) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
已过时。
Using Java serialization for persisting state is not encouraged. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getSerializedAccumulatorResults() - 类 中的方法org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getSerializedExecutionConfig() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
getSerializedExecutionConfig() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns the ExecutionConfig
getSerializedJobInformation() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Return the sub task's serialized job information.
getSerializedTaskInformation() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Return the sub task's serialized task information.
getSerializedThrowable() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
Returns an empty Optional if the job finished successfully, otherwise the Optional will carry the failure cause.
getSerializedUserAccumulators() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
 
getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Returns the serialized value for the given key and namespace.
getSerializer(T) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint.
getSerializer(int) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint version.
getSerializerSnapshotsImmutable() - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getServerAddress() - 接口 中的方法org.apache.flink.runtime.query.KvStateServer
Returns the address the server is listening to.
getServerAddress() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
Returns the address on which this endpoint is accepting requests.
getServerChannelHandlers() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyProtocol
Returns the server channel handlers.
getServerConnectBacklog() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getServerNumThreads() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getServerPort() - 接口 中的方法org.apache.flink.runtime.webmonitor.WebMonitor
Gets the port that the web server actually binds to.
getSessionTimeout() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the shared slot into which this constraint's tasks are places.
getSharedSlotForTask(AbstractID, Iterable<TaskManagerLocation>, boolean) - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
getSharedState() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getSharedStateDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getSharedStateHandleIDs() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getSharedStateHandleIDs() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getSharedStateRegistry() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getShipStrategyName() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Gets the name of the ship strategy for the represented input, like "forward", "partition hash", "rebalance", "broadcast", ...
getShutDownFuture() - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
 
getSize() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getSize() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Gets the size (in bytes) of the file underlying the channel.
getSize() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns the size of the written data, i.e. the writer index, of this buffer.
getSize() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getSize() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getSize() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
Size (#bytes of the serialized data) of the rpc invocation message.
getSizeLimit() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
getSizeOfFreeHeapMemory() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets an estimate of the size of the free heap memory.
getSizeOfFreeHeapMemoryWithDefrag() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets an estimate of the size of the free heap memory.
getSizeOfJvmHeap() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
Returns the size of the JVM heap memory
getSizeOfManagedMemory() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
Returns the size of the memory managed by the system for caching, hashing, sorting, ...
getSizeOfPhysicalMemory() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
Returns the size of physical memory in bytes available on the compute node.
getSizeOfPhysicalMemory() - 类 中的静态方法org.apache.flink.runtime.util.Hardware
Returns the size of the physical memory in bytes.
getSizeUnsafe() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns the size of the written data, i.e. the writer index, of this buffer in an non-synchronized fashion.
getSizeUnsafe() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getSizeUnsafe() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getSlot() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
getSlotContext() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the allocated slot that this slot refers to.
getSlotForTask(JobVertexID, Iterable<TaskManagerLocation>) - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot suitable for the given task vertex.
getSlotForTask(CoLocationConstraint, Iterable<TaskManagerLocation>) - 类 中的方法org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot for a task that has a co-location constraint.
getSlotId() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getSlotID() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
Get the unique identification of this slot.
getSlotIndex() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
 
getSlotIndex() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getSlotInfo() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
 
getSlotManager() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
getSlotManagerConfiguration() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
getSlotNumber() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
 
getSlotNumber() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the number of the slot.
getSlotProvider() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getSlotRequestId() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getSlotRequestId() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getSlotRequestId() - 类 中的方法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() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the slot request id uniquely identifying the request with which this slot has been allocated.
getSlotRequestId() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getSlotRequestId() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
 
getSlotRequestTimeout() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getSlotRequestTimeout() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getSlotSharingGroup() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getSlotSharingGroup() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Gets the slot sharing group that this vertex is associated with.
getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getSlotSharingGroupId() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the slot sharing group id to which this slot belongs.
getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getSnapshot() - 类 中的方法org.apache.flink.runtime.accumulators.AccumulatorRegistry
Creates a snapshot of this accumulator registry.
getSolutionSetComparator(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getSolutionSetSerializer(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getSource() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getSource() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Returns the data set at the source of the edge.
getSourceId() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Gets the ID of the consumed data set.
getSpillingDirectories() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the directories that the I/O manager spills to.
getSpillingDirectoriesPaths() - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getSpillingThresholdDriver() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getSpillingThresholdInput(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getSplitAssigner() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getSSLEnabled() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getSslHandlerFactory() - 类 中的方法org.apache.flink.runtime.rest.RestClientConfiguration
Returns the SSLEngine that the REST client endpoint should use.
getSslHandlerFactory() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the SSLEngine that the REST server endpoint should use.
getStackTrace() - 类 中的方法org.apache.flink.runtime.messages.StackTrace
 
getStackTraces() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the a map of stack traces by execution ID.
getStartCommand(String, Map<String, String>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Replaces placeholders in the template start command with values from startCommandValues.
getStartKeyGroup() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
getStartTime() - 类 中的方法org.apache.flink.runtime.client.JobStatusMessage
 
getStartTime() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getStartTime() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the time stamp, when the sample was triggered.
getStartTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getStartTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getStartTime() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getState(int) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getState(int) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getState() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getState() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the current ExecutionState for this execution.
getState() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the current JobStatus for this execution graph.
getState() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getState() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getState() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getState() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getState() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
getState() - 类 中的方法org.apache.flink.runtime.query.KvStateEntry
 
getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getState() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
getState() - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
Returns the internal data structure.
getState() - 接口 中的方法org.apache.flink.runtime.state.StateEntry
Returns the state of this entry.
getState() - 类 中的方法org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
 
getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
 
getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
getStateIncrementalVisitor(int) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Get global visitor of state entries.
getStateMetaInfo() - 接口 中的方法org.apache.flink.runtime.state.BackendWritableBroadcastState
 
getStateMetaInfo() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
getStateMetaInfo() - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
getStateMetaInfoSnapshots() - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getStateNameToPartitionOffsets() - 接口 中的方法org.apache.flink.runtime.state.OperatorStateHandle
Returns a map of meta data for all contained states by their name.
getStateNameToPartitionOffsets() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
getStates() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getStates() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getStateSerializer() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getStateSerializer() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
getStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getStateServerPortRange() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the port range where the queryable state client proxy can listen.
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total checkpoint state size over all subtasks.
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the size of the checkpointed state at this subtask.
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
getStateSize() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the total checkpoint state size over all subtasks.
getStateSize() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
getStateSize() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getStateSize() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getStateSize() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getStateSize() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
Returns the file size in bytes.
getStateSize() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
getStateSize() - 类 中的方法org.apache.flink.runtime.state.SnapshotResult
 
getStateSize() - 接口 中的方法org.apache.flink.runtime.state.StateObject
Returns the size of the state in bytes.
getStateSize(StateObject) - 类 中的静态方法org.apache.flink.runtime.state.StateUtil
Returns the size of a state object
getStateSizeStats() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the state size of completed checkpoints.
getStateSizeStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the state size.
getStateSnapshotTransformFactory() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getStateTable() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
This should only be used for testing.
getStateTimestamp(ExecutionState) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the timestamp for the given ExecutionState.
getStateTimestamp(ExecutionState) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the timestamp for the given ExecutionState.
getStateTimestamp(ExecutionState) - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getStateTimestamp(ExecutionState) - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getStateTimestamp(ExecutionState) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getStateTimestamp(ExecutionState) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getStateTimestamps() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the timestamps for every ExecutionState.
getStateTimestamps() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getStateTimestamps() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getStateType() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
getStateValueSerializer() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
 
getStatistics() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
getStatus() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the status of this checkpoint.
getStatus() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getStatus() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getStatus() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getStatus() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
getStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
getStatusTimestamp(JobStatus) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the timestamp for the given JobStatus.
getStatusTimestamp(JobStatus) - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getStatusTimestamp(JobStatus) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getStdDev() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getStorageLocation(JobID, BlobKey) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
Returns a file handle to the file associated with the given blob key on the blob server.
getStoredJobsOverview() - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Return the JobsOverview for all stored/past jobs.
getStoredJobsOverview() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getStoredJobsOverview() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Gets the name of the failover strategy, for logging purposes.
getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
getStream() - 类 中的方法org.apache.flink.runtime.state.StatePartitionStreamProvider
Returns a stream with the data of one state partition.
getStrictObjectMapper() - 类 中的静态方法org.apache.flink.runtime.rest.util.RestMapperUtils
Returns a preconfigured ObjectMapper.
getStub() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
getStub() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
getStub() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getStubParameter(String, String) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getStubParameters() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
getStubType() - 接口 中的方法org.apache.flink.runtime.operators.Driver
Gets the class of the stub type that is run by this task.
getStubType() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
getStubType() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
getStubWrapper(ClassLoader) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getSubmittedJobGraphStore() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the submitted job graph store for the job manager
getSubmittedJobGraphStore() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getSubmittedJobGraphStore() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getSubsetForKeyGroup(int) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
 
getSubsetForKeyGroup(int) - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
getSubsetForKeyGroup(int) - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
getSubtaskCheckpointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
getSubtaskId() - 类 中的方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
getSubtaskIndex() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the subtask index.
getSubtaskIndex() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's index in the subtask group.
getSubtaskIndex() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getSubtaskMetricStore(String, String, int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the given job/task ID and subtask index.
getSubtaskMetricStore(int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
 
getSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
getSubtaskState() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getSubtaskStateByOperatorID(OperatorID) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
Returns the subtask state for the given operator id (or null if not contained).
getSubtaskStateMappings() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
Returns the set of all mappings from operator id to the corresponding subtask state.
getSubtaskStates() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
getSubtaskStates() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
getSubtaskStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the stats for all subtasks.
getSuccessfulCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getSum() - 类 中的方法org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the sum of all seen values.
getSum() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getSummary() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
getSummary() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
getSummaryStats() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted completed checkpoint summary stats.
getSummaryStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the summary of the subtask stats.
getSuperstep() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getSupportedAPIVersions() - 接口 中的方法org.apache.flink.runtime.rest.handler.RestHandlerSpecification
Returns the supported API versions that this request supports.
getSyncCheckpointDuration() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the synchronous part of the checkpoint.
getSyncCheckpointDurationStats() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the sync checkpoint duration.
getSyncDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
getSyncDurationMillis() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getSynchronousDuration() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
getSystemProperties() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the system properties.
getSystemResourceMetricsProbingInterval() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTarget() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getTarget() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Returns the vertex connected to this edge.
getTargetAddress() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
getTargetAddress() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getTargetAddress() - 类 中的方法org.apache.flink.runtime.resourcemanager.SlotRequest
 
getTargetDirectory() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
getTargetGateway() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
Gets the RegisteredGateway.
getTargetLeaderId() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
getTargetLocation() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointOptions
Returns the target location for the checkpoint.
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
 
getTargetRestEndpointURL() - 接口 中的方法org.apache.flink.runtime.rest.handler.RestHandlerSpecification
Returns the generalized endpoint url that this request should be sent to, for example /job/:jobid.
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
已过时。
 
getTargetRestEndpointURL() - 类 中的方法org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
已过时。
 
getTargetSlotNumber() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Gets the number of the slot into which the task is to be deployed.
getTask(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the task for the given execution attempt id.
getTaskAssignment() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getTaskConfig() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getTaskConfig() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getTaskConfig() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getTaskConfiguration() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the task-wide configuration object, originally attached to the job vertex.
getTaskConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getTaskConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the task configuration object which was attached to the original JobVertex.
getTaskConfiguration() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskConfiguration() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getTaskEventDispatcher() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getTaskEventDispatcher() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
getTaskEventDispatcher() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskExecutionId() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getTaskExecutorGateway() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getTaskFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskInfo() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the TaskInfo object associated with this subtask
getTaskInfo() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskInfo() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
getTaskInformationOrBlobKey() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getTaskKvStateRegistry() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the registry for InternalKvState instances.
getTaskKvStateRegistry() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskLocalSnapshot() - 类 中的方法org.apache.flink.runtime.state.SnapshotResult
 
getTaskManagerActions() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getTaskManagerAddress() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTaskManagerBindAddress() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getTaskManagerConnection() - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getTaskManagerConnection() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getTaskManagerFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskManagerGateway() - 类 中的方法org.apache.flink.runtime.instance.Instance
Returns the InstanceGateway of this Instance.
getTaskManagerGateway() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlotContext
 
getTaskManagerGateway() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the actor gateway that can be used to send messages to the TaskManager.
getTaskManagerGateway() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Return the TaskManager gateway to talk to the TaskManager.
getTaskManagerGateway() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotContext
Gets the actor gateway that can be used to send messages to the TaskManager.
getTaskManagerGateway() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getTaskManagerID() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getTaskManagerID() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the ID of the TaskManager that offers this slot.
getTaskManagerInfo() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Gets the task manager info, with configuration and hostname.
getTaskManagerInfo() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
getTaskManagerInfo() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getTaskManagerInfo() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskManagerInfos() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
getTaskManagerJobFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskManagerLocation() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getTaskManagerLocation() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlotContext
 
getTaskManagerLocation() - 类 中的方法org.apache.flink.runtime.instance.Slot
Gets the location info of the TaskManager that offers this slot.
getTaskManagerLocation() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Return the TaskManager location of this slot.
getTaskManagerLocation() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotInfo
Gets the location info of the TaskManager that offers this slot.
getTaskManagerLocation() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getTaskManagerLocation() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskManagerLocationFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getTaskManagerLogPath() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTaskManagerMetricStore(String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.TaskManagerMetricStore for the given taskmanager ID.
getTaskManagerRequestTimeout() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskManagers() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
getTaskManagerShellCommand(Configuration, ContaineredTaskManagerParameters, String, String, boolean, boolean, boolean, Class<?>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Generates the shell command to start a task manager.
getTaskManagerSlotId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
getTaskManagerStateStore() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskManagerStdoutPath() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTaskManagerTimeout() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskMetricStore(String, String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the given job/task ID.
getTaskName() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getTaskName() - 类 中的方法org.apache.flink.runtime.executiongraph.TaskInformation
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
getTaskName() - 异常错误 中的方法org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
getTaskName() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getTaskNameWithSubtaskIndex() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the name of this execution vertex in the format "myTask (2/7)".
getTaskNameWithSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getTaskNameWithSubtaskIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Creates a simple name representation in the style 'taskname (x/y)', where 'taskname' is the name as returned by ExecutionVertex.getTaskName(), 'x' is the parallel subtask index as returned by ExecutionVertex.getParallelSubtaskIndex()+ 1, and 'y' is the total number of tasks, as returned by ExecutionVertex.getTotalNumberOfParallelSubtasks().
getTaskOwnedStateDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getTaskRestore() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getTaskRestore() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getTasks() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Get all tasks running in this task slot.
getTasks(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator over all tasks for a given job.
getTaskSlotTable() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTasksPerState() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getTasksPerState() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getTaskStateManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getTaskStateManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskStates() - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.Savepoint
已过时。
Only kept for backwards-compatibility with versionS < 1.3. Will be removed in the future.
getTaskStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getTaskStates() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getTaskStateSnapshot() - 类 中的方法org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
 
getTaskStateStats(JobVertexID) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getTaskVertices() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns all execution vertices for this job vertex.
getTaskVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getTaskVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getTemporaryFileDirectory() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Gets the directory for temporary files, as returned by the JVM system property "java.io.tmpdir".
getTerminalStateFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Gets a future that completes once the task execution reaches a terminal state.
getTerminalStateFuture() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
Gets the terminal state future which is completed once the payload has reached a terminal state.
getTerminationFuture() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
getTerminationFuture() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the termination future of this ExecutionGraph.
getTerminationFuture() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getTerminationFuture() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Return a future which is completed with true when the rpc endpoint has been terminated.
getTerminationFuture() - 接口 中的方法org.apache.flink.runtime.rpc.RpcServer
Return a future which is completed when the rpc endpoint has been terminated.
getTerminationFuture() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Returns a future indicating when the RPC service has been shut down.
getTerminationFuture() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
getThreadPriority() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
 
getThrowableType(Throwable) - 类 中的静态方法org.apache.flink.runtime.throwable.ThrowableClassifier
Classify the exceptions by extracting the ThrowableType from a potential ThrowableAnnotation.
getTimeNanos() - 类 中的方法org.apache.flink.runtime.rpc.messages.RunAsync
 
getTimeout() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getTimeout() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
 
getTimeout() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTimerServiceShutdownTimeout() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
getTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getTimestamp() - 类 中的方法org.apache.flink.runtime.executiongraph.ErrorInfo
Returns the timestamp for the contained exception.
getTimestamp() - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getTimestamp() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
getTimestamp() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
getTimestamps() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getTimeZoneName() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getTimeZoneOffset() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getTmpDirectories() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTmpDirectories() - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets the list of temporary file directories.
getTmpDirectory() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getTmpDirPaths() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTotalFields() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getTotalNumberCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getTotalNumberOfBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfBytes() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the total number of checkpoints (in progress, completed, failed).
getTotalNumberOfMemorySegments() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getTotalNumberOfParallelSubtasks() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getTotalNumberOfSlots() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
getTotalNumberOfSlots() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
getTotalNumberOfSlots() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getTotalNumberOfVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getTotalNumPages() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Gets the total number of memory pages managed by this memory manager.
getTransientBlobService() - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
 
getTransientBlobService() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
getTransientBlobService() - 接口 中的方法org.apache.flink.runtime.blob.BlobService
Returns a BLOB service for accessing transient BLOBs.
getTransportType() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
getTriggerId() - 类 中的方法org.apache.flink.runtime.rest.handler.async.OperationKey
Get the trigger id for the given operation key.
getTriggerId() - 类 中的方法org.apache.flink.runtime.rest.handler.async.TriggerResponse
 
getTriggerTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the timestamp when the checkpoint was triggered.
getTriggerTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getType() - 类 中的方法org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getType() - 异常错误 中的方法org.apache.flink.runtime.broadcast.InitializationTypeConflictException
 
getType() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
getTypeClass() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getTypeSerializer(String) - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
TODO this method should be removed once the serializer map is removed.
getTypeSerializerSnapshot(String) - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getTypeSerializerSnapshot(StateMetaInfoSnapshot.CommonSerializerKeys) - 类 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
getUdfRuntimeContext() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getUnannouncedCredit() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Gets the currently unannounced credit.
getUnfencedMainThreadExecutor() - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
Returns a main thread executor which is not bound to the fencing token.
getUnionListState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
getUnresolvedMessageParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
 
getUnresolvedMessageParameters() - 接口 中的方法org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
Returns a new MessageParameters object.
getUploadDir() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the directory used to temporarily store multipart/form-data uploads.
getUploadedFiles() - 类 中的方法org.apache.flink.runtime.rest.handler.FileUploads
 
getUploadedFiles() - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
 
getURLVersionPrefix() - 枚举 中的方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
Returns the URL version prefix (e.g.
getUseLargeRecordHandler() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getUserAccumulators() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getUserAccumulators() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
getUserAccumulatorsStringified() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
Returns the user-defined accumulators as strings.
getUserAccumulatorsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getUserAccumulatorsStringified() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getUserArtifacts() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Gets the list of assigned user jar paths.
getUserClassLoader() - 接口 中的方法org.apache.flink.runtime.execution.Environment
Returns the user code class loader
getUserClassLoader() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getUserClassLoader() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getUserCodeClassLoader() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the user code class loader of this invokable.
getUserCodeClassLoader() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
 
getUserCodeClassLoaderInfo(ClassLoader) - 类 中的静态方法org.apache.flink.runtime.util.ClassLoaderUtil
Gets information about URL class loaders.
getUserDefinedOperatorIDs() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the alternative IDs of all operators contained in this execution job vertex.
getUserDefinedOperatorIDs() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
getUserJarBlobKeys() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns a set of BLOB keys referring to the JAR files required to run this job.
getUserJars() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Gets the list of assigned user jar paths.
getUserMap() - 类 中的方法org.apache.flink.runtime.accumulators.AccumulatorRegistry
Gets the map for user-defined accumulators.
getUserValue() - 类 中的方法org.apache.flink.runtime.state.ttl.TtlValue
 
getValue() - 类 中的方法org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getValue() - 类 中的方法org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
getValue() - 类 中的方法org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
getValue() - 类 中的方法org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
getValue() - 类 中的方法org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
getValue() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
getValue() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.Metric
 
getValue() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
getValue() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Returns the resolved value of this parameter, or null if it isn't resolved yet.
getValue() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
getValue() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
 
getValueClass() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
Returns the class of the value wrapped in the AsynchronousOperationResult.
getValueClass() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getValueClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
 
getValueClass() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getValues() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getValues() - 接口 中的方法org.apache.flink.runtime.util.KeyGroupedIterator
 
getValues() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValues() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValues1() - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
getValues1() - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
getValues1() - 接口 中的方法org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Returns an iterable over the left input values for the current key.
getValues2() - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
getValues2() - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
getValues2() - 接口 中的方法org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Returns an iterable over the left input values for the current key.
getValueSerializer() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of value this state holds.
getValueSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
getVariable() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVariable(BroadcastVariableInitializer<T, C>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVersion() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getVersion() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getVersion() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
getVersion() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getVersion() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
getVersion() - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getVersion() - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getVersion() - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Returns the version of the code as String.
getVersionedValue() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
getVertex() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getVertexId() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getVertexWithAttempt() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
getVertices() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns an Iterable to iterate all vertices registered with the job graph.
getVerticesAsArray() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Returns an array of all job vertices that are registered with the job graph.
getVerticesSortedTopologicallyFromSources() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
getVerticesToAcknowledge() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVerticesToConfirm() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVerticesTopologically() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns an iterable containing all job vertices for this execution graph in the order they were created.
getVerticesTopologically() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getVerticesTopologically() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getVerticesToTrigger() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getWaitForSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
getWebMonitorEndpoint() - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
 
getWebMonitorLeaderElectionService() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
 
getWebMonitorLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getWebMonitorLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getWebMonitorLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getWebMonitorLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
 
getWebMonitorLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getWebMonitorLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getWebMonitorLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getWebUiDir() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getWebUIPort() - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getWorker() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getWorkerIndex() - 类 中的方法org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
getWrappedException() - 异常错误 中的方法org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
getWriteEnd() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
Called by iteration tail to save the output of the current superstep.
getWriteOffset() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
 
getWriter(int) - 接口 中的方法org.apache.flink.runtime.execution.Environment
 
getWriter() - 类 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
Returns the writer for StateMetaInfoSnapshot.
getWriter(int) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getWriters() - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputCollector
List of writers that are associated with this output collector
getWrittenBytes() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
getZooKeeperEnsemble(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not tolerate it).
getZooKeeperLoginContextName() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
getZooKeeperServiceName() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
GlobalAggregateManager - org.apache.flink.runtime.taskexecutor中的接口
This interface gives access to transient, named, global aggregates.
GlobalModVersionMismatch - 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) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
go() - 类 中的方法org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Entry point of the thread.
go() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
The entry point for the thread.
go() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Entry point of the thread.
go() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Entry point of the thread.
go() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Equivalent to the run() method.
grantLeadership(UUID) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
Callback method when current resourceManager is granted leadership.
grantLeadership(UUID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
grantLeadership(UUID) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon selecting this instance as the new leader.
grantLeadership(UUID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager is granted leadership.
grantLeadership(UUID) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
GroupCombineChainedDriver<IN,OUT> - org.apache.flink.runtime.operators.chaining中的类
Chained variant of the GroupReduceCombineDriver Acts like a combiner with a custom output type OUT.
GroupCombineChainedDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
GroupReduceCombineDriver<IN,OUT> - 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() - 类 的构造器org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
GroupReduceDriver<IT,OT> - org.apache.flink.runtime.operators中的类
GroupReduce task which is executed by a Task Manager.
GroupReduceDriver() - 类 的构造器org.apache.flink.runtime.operators.GroupReduceDriver
 

H

HadoopConfOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays a Hadoop configuration into a container, based on a supplied Hadoop configuration directory.
HadoopConfOverlay(File) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
HadoopConfOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the HadoopConfOverlay.
HadoopModule - org.apache.flink.runtime.security.modules中的类
Responsible for installing a Hadoop login user.
HadoopModule(SecurityConfiguration, Configuration) - 类 的构造器org.apache.flink.runtime.security.modules.HadoopModule
 
HadoopModuleFactory - org.apache.flink.runtime.security.modules中的类
HadoopModuleFactory() - 类 的构造器org.apache.flink.runtime.security.modules.HadoopModuleFactory
 
HadoopUserOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays a Hadoop user context into a container.
HadoopUserOverlay(UserGroupInformation) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
HadoopUserOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the HadoopUserOverlay.
handIn(String, V) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.Broker
Hand in the object to share.
handleAsyncIfNotDone(CompletableFuture<IN>, Executor, BiFunction<? super IN, Throwable, ? extends OUT>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
This function takes a CompletableFuture and a handler function for the result of this future.
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, M>, AbstractCheckpointStats) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
Called for each request with the corresponding AbstractCheckpointStats instance.
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, CheckpointMessageParameters>, AbstractCheckpointStats) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
 
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, TaskCheckpointMessageParameters>, AbstractCheckpointStats) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
 
handleError(Exception) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
Handles error occurring in the leader election service.
handleError(Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
handleError(Exception) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by LeaderElectionService in case of an error in the service thread.
handleError(Exception) - 接口 中的方法org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
This method is called by the LeaderRetrievalService in case of an exception.
handleError(Exception) - 类 中的方法org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
handleError(Exception) - 类 中的方法org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
handleError(Throwable) - 接口 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Callback to report occurring errors.
handleError(Exception) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Handles error occurring in the leader election service.
handleError(Throwable) - 接口 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback for errors which might occur in the JobLeaderService.
handleError(Exception) - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
handleError(Exception) - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
handleError(Exception) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
handleError(Exception) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
handleEvent(AbstractEvent) - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
Handles the event and returns whether the reader reached an end-of-stream event (either the end of the whole stream or the end of an superstep).
handleException(E) - 接口 中的方法org.apache.flink.runtime.operators.sort.ExceptionHandler
This method is called when the handler should deal with an exception.
handleMessage(Object) - 类 中的方法org.apache.flink.runtime.akka.FlinkUntypedActor
This method contains the actor logic which defines how to react to incoming messages.
handleProcessedBuffer(T, IOException) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handles a processed Buffer.
handleRequest(HandlerRequest<R, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractRestHandler
This method is called for every incoming request and returns a CompletableFuture containing a the response.
handleRequest(HandlerRequest<EmptyRequestBody, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
 
handleRequest(HandlerRequest<B, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
Called for each request after the corresponding AccessExecutionGraph has been retrieved from the ExecutionGraphCache.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
Called for each request after the corresponding AccessExecutionJobVertex has been retrieved from the AccessExecutionGraph.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecution) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
Called for each request after the corresponding AccessExecution has been retrieved from the AccessExecutionVertex.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
Called for each request after the corresponding AccessExecutionVertex has been retrieved from the AccessExecutionJobVertex.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobAccumulatorsMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobExecutionResultHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobIdsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobPlanHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
 
handleRequest(HandlerRequest<JobSubmitRequestBody, EmptyMessageParameters>, DispatcherGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobSubmitHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobTerminationMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobTerminationHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, P>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskMessageParameters>, AccessExecutionVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskAttemptMessageParameters>, AccessExecution) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskAttemptMessageParameters>, AccessExecution) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, TaskManagerMessageParameters>, ResourceManagerGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, ResourceManagerGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
 
handleRpcMessage(Object) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
HandlerRedirectUtils - org.apache.flink.runtime.rest.handler.util中的类
Utilities to extract a redirect address.
HandlerRedirectUtils() - 类 的构造器org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
HandlerRequest<R extends RequestBody,M extends MessageParameters> - org.apache.flink.runtime.rest.handler中的类
Simple container for the request to a handler, that contains the RequestBody and path/query parameters.
HandlerRequest(R, M) - 类 的构造器org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequest(R, M, Map<String, String>, Map<String, List<String>>) - 类 的构造器org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequest(R, M, Map<String, String>, Map<String, List<String>>, Collection<File>) - 类 的构造器org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequestException - org.apache.flink.runtime.rest.handler中的异常错误
Base class for all HandlerRequest related exceptions.
HandlerRequestException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.handler.HandlerRequestException
 
HandlerRequestException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.handler.HandlerRequestException
 
HandlerRequestException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.handler.HandlerRequestException
 
HandlerRequestUtils - org.apache.flink.runtime.rest.handler.util中的类
Utils for getting query parameters from HandlerRequest.
HandlerRequestUtils() - 类 的构造器org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
 
HandlerUtils - org.apache.flink.runtime.rest.handler.util中的类
Utilities for the REST handlers.
HandlerUtils() - 类 的构造器org.apache.flink.runtime.rest.handler.util.HandlerUtils
 
handleStateChange(ConnectionState) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
handleStateChange(ConnectionState) - 类 中的方法org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
handleUncaughtException(CompletableFuture<?>, Thread.UncaughtExceptionHandler) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Checks that the given CompletableFuture is not completed exceptionally.
HandshakeException - org.apache.flink.runtime.rpc.exceptions中的异常错误
Exception which signals a handshake failure.
HandshakeException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeSuccessMessage - org.apache.flink.runtime.rpc.messages中的枚举
Handshake success response.
Hardware - org.apache.flink.runtime.util中的类
Convenience class to extract hardware specifics of the computer executing the running JVM.
HardwareDescription - org.apache.flink.runtime.instance中的类
A hardware description describes the resources available to a task manager.
HardwareDescription(int, long, long, long) - 类 的构造器org.apache.flink.runtime.instance.HardwareDescription
Constructs a new hardware description object.
hasAllocatedSlots(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the job has allocated (not active) slots.
hasArray() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
hasBackPressure() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
hasBroadcastVariable(String) - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
hasChildren() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
Checks whether this shared slot has any sub slots.
hasClassLoader(JobID) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
hasClassLoader(JobID) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
True if the LibraryCacheManager has a user code class loader registered for the given job id.
hasData() - 类 中的方法org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
hasDefaultSavepointLocation() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Checks whether the storage has a default savepoint location configured.
hasDefaultSavepointLocation() - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
hasFurtherInput() - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
Checks, whether the input that is blocked by this iterator, has further elements available.
hasFurtherInput() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
Checks, whether the input that is blocked by this iterator, has further elements available.
hash(int, int) - 类 中的静态方法org.apache.flink.runtime.operators.hash.MutableHashTable
The level parameter is needed so that we can have different hash functions when we recursively apply the partitioning, so that the working set eventually fits into memory.
hashCode() - 类 中的方法org.apache.flink.runtime.blob.BlobKey
 
hashCode() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointOptions
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
hashCode() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceID
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
hashCode() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
 
hashCode() - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
hashCode() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
 
hashCode() - 类 中的方法org.apache.flink.runtime.instance.Slot
Slots must always has based on reference identity.
hashCode() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
 
hashCode() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
hashCode() - 类 中的方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
hashCode() - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
hashCode() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
hashCode() - 异常错误 中的方法org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
hashCode() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
hashCode() - 类 中的方法org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
hashCode() - 类 中的方法org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.Acknowledge
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
hashCode() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.handler.async.OperationKey
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
This method should only be called in tests!
hashCode() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.VoidNamespace
 
hashCode() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
hashCode() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
hashCode() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
 
hashCode() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
hashCode() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
 
hashCode() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
hashCode() - 类 中的方法org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
 
hashCode() - 类 中的方法org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
hashJoin - 类 中的变量org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
hashJoin - 类 中的变量org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
hashJoin - 类 中的变量org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
hashJoin - 类 中的变量org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
HashJoinIteratorBase - org.apache.flink.runtime.operators.hash中的类
Common methods for all Hash Join Iterators.
HashJoinIteratorBase() - 类 的构造器org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
 
HashPartition<BT,PT> - org.apache.flink.runtime.operators.hash中的类
 
HashPartition.BuildSideBuffer - org.apache.flink.runtime.operators.hash中的类
 
HashPartitionIterator<BT,PT> - org.apache.flink.runtime.iterative.io中的类
Iterator over the build side entries of a HashPartition.
HashPartitionIterator(Iterator<HashPartition<BT, PT>>, TypeSerializer<BT>) - 类 的构造器org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
HashTableProber(TypeComparator<PT>, TypePairComparator<PT, T>) - 类 的构造器org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
hasLeadership(UUID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
hasLeadership(UUID) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderElectionService
Returns true if the LeaderContender with which the service has been started owns currently the leadership under the given leader session id.
hasLeadership(UUID) - 类 中的方法org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
hasLeadership(UUID) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
hasMemoryAddress() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
hasNewNetworkBufConf(Configuration) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns whether the new network buffer memory configuration is present in the configuration object, i.e. at least one new parameter is given or the old one is not present.
hasNext() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.Reader
 
hasNext() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.RecordReader
 
hasNext() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
hasNext() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
Whether the visitor potentially has some next entries to return from nextEntries().
hasNext() - 类 中的方法org.apache.flink.runtime.util.EmptyIterator
Always returns false, since this iterator is empty.
hasNext() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
hasNext() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
hasNext() - 类 中的方法org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
hasNext() - 类 中的方法org.apache.flink.runtime.util.SingleElementIterator
 
hasNoConnectedInputs() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
hasQuarantined(String, ActorSystem) - 类 中的方法org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
hasQuarantined(String, ActorSystem) - 接口 中的方法org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system has quarantined the given remote actor system.
hasReachedEndOfFile() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
hasReachedEndOfFile() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
hasReachedEndOfFile() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
hasReachedEndOfFile() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
hasReachedEndOfFile() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
hasReachedEndOfSuperstep() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
hasReachedEndOfSuperstep() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
hasResourcesAvailable() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
hasSerializedData() - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
 
hasSerializedData() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
hasState() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
hasState() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
Returns true if this contains at least one StateObject.
hasState() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
Returns true if at least one OperatorSubtaskState in subtaskStatesByOperatorID has state.
hasStubWrapper() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
hasUnfinishedData() - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
hasUnfinishedData() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
hasUsercodeJarFiles() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Checks whether the JobGraph has user code JAR files attached.
HEAD_BLOCK_LENGTH_OFFSET - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The offset to the header field indicating the number of bytes in the block
HEADER_FLAGS_OFFSET - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The offset to the flags in the header;
HEADER_LENGTH - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The length of the header put into the blocks.
HEADER_MAGIC_NUMBER - 类 中的静态变量org.apache.flink.runtime.checkpoint.Checkpoints
Magic number at the beginning of every checkpoint metadata file, for sanity checks.
HEADER_MAGIC_NUMBER - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The magic number that identifies blocks as blocks from a ChannelWriterOutputView.
headerLength - 类 中的变量org.apache.flink.runtime.memory.AbstractPagedInputView
 
headerLength - 类 中的变量org.apache.flink.runtime.memory.AbstractPagedOutputView
 
HeaderlessChannelReaderInputView - org.apache.flink.runtime.io.disk.iomanager中的类
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, int, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
Creates a new channel reader that reads from the given channel, expecting a specified number of blocks in the channel, and returns only a specified number of bytes from the last block.
HeapBroadcastState<K,V> - org.apache.flink.runtime.state中的类
A Broadcast State backed a heap-based Map.
heapBuffer() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
heapBuffer(int) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
heapBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
HeapKeyedStateBackend<K> - org.apache.flink.runtime.state.heap中的类
A AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to streams provided by a CheckpointStreamFactory upon checkpointing.
HeapKeyedStateBackend(TaskKvStateRegistry, StateSerializerProvider<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, CloseableRegistry, StreamCompressionDecorator, Map<String, StateTable<K, ?, ?>>, Map<String, HeapPriorityQueueSnapshotRestoreWrapper>, LocalRecoveryConfig, HeapPriorityQueueSetFactory, HeapSnapshotStrategy<K>) - 类 的构造器org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
HeapKeyedStateBackendBuilder<K> - org.apache.flink.runtime.state.heap中的类
Builder class for HeapKeyedStateBackend which handles all necessary initializations and clean ups.
HeapKeyedStateBackendBuilder(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, Collection<KeyedStateHandle>, StreamCompressionDecorator, LocalRecoveryConfig, HeapPriorityQueueSetFactory, boolean, CloseableRegistry) - 类 的构造器org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder
 
HeapPriorityQueue<T extends HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的类
Basic heap-based priority queue for HeapPriorityQueueElement objects.
HeapPriorityQueue(PriorityComparator<T>, int) - 类 的构造器org.apache.flink.runtime.state.heap.HeapPriorityQueue
Creates an empty HeapPriorityQueue with the requested initial capacity.
HeapPriorityQueueElement - org.apache.flink.runtime.state.heap中的接口
Interface for objects that can be managed by a HeapPriorityQueue.
HeapPriorityQueueSet<T extends HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的类
A heap-based priority queue with set semantics, based on HeapPriorityQueue.
HeapPriorityQueueSet(PriorityComparator<T>, KeyExtractorFunction<T>, int, KeyGroupRange, int) - 类 的构造器org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
Creates an empty HeapPriorityQueueSet with the requested initial capacity.
HeapPriorityQueueSetFactory - org.apache.flink.runtime.state.heap中的类
HeapPriorityQueueSetFactory(KeyGroupRange, int, int) - 类 的构造器org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory
 
HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的类
This wrapper combines a HeapPriorityQueue with backend meta data.
HeapPriorityQueueSnapshotRestoreWrapper(HeapPriorityQueueSet<T>, RegisteredPriorityQueueStateBackendMetaInfo<T>, KeyExtractorFunction<T>, KeyGroupRange, int) - 类 的构造器org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
 
HeapPriorityQueueStateSnapshot<T> - org.apache.flink.runtime.state.heap中的类
This class represents the snapshot of an HeapPriorityQueueSet.
HeapRestoreOperation<K> - org.apache.flink.runtime.state.heap中的类
Implementation of heap restore operation.
HeapSort - org.apache.flink.runtime.operators.sort中的类
 
HeapSort() - 类 的构造器org.apache.flink.runtime.operators.sort.HeapSort
 
heartbeatFromJobManager(ResourceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
heartbeatFromJobManager(ResourceID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the heartbeat to resource manager from job manager
heartbeatFromJobManager(ResourceID, AllocatedSlotReport) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
heartbeatFromJobManager(ResourceID, AllocatedSlotReport) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Heartbeat request from the job manager.
heartbeatFromResourceManager(ResourceID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
heartbeatFromResourceManager(ResourceID) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Sends heartbeat request from the resource manager.
heartbeatFromResourceManager(ResourceID) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
heartbeatFromResourceManager(ResourceID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Heartbeat request from the resource manager.
heartbeatFromTaskManager(ResourceID, AccumulatorReport) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
heartbeatFromTaskManager(ResourceID, AccumulatorReport) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Sends the heartbeat to job manager from task manager.
heartbeatFromTaskManager(ResourceID, SlotReport) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
heartbeatFromTaskManager(ResourceID, SlotReport) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the heartbeat to resource manager from task manager
heartbeatInterval - 类 中的变量org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat interval for the created services.
HeartbeatListener<I,O> - org.apache.flink.runtime.heartbeat中的接口
Interface for the interaction with the HeartbeatManager.
HeartbeatManager<I,O> - org.apache.flink.runtime.heartbeat中的接口
A heartbeat manager has to be able to start/stop monitoring a HeartbeatTarget, and report heartbeat timeouts for this target.
HeartbeatManagerImpl<I,O> - org.apache.flink.runtime.heartbeat中的类
Heartbeat manager implementation.
HeartbeatManagerImpl(long, ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - 类 的构造器org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
HeartbeatManagerSenderImpl<I,O> - org.apache.flink.runtime.heartbeat中的类
HeartbeatManager implementation which regularly requests a heartbeat response from its monitored HeartbeatTarget.
HeartbeatServices - org.apache.flink.runtime.heartbeat中的类
HeartbeatServices gives access to all services needed for heartbeating.
HeartbeatServices(long, long) - 类 的构造器org.apache.flink.runtime.heartbeat.HeartbeatServices
 
HeartbeatTarget<I> - org.apache.flink.runtime.heartbeat中的接口
Interface for components which can be sent heartbeats and from which one can request a heartbeat response.
heartbeatTimeout - 类 中的变量org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat timeout for the created services.
hierarchy() - 类 中的方法org.apache.flink.runtime.instance.Slot
 
HighAvailabilityMode - org.apache.flink.runtime.jobmanager中的枚举
High availability mode for Flink's cluster execution.
HighAvailabilityServices - org.apache.flink.runtime.highavailability中的接口
The HighAvailabilityServices give access to all services needed for a highly-available setup.
HighAvailabilityServicesFactory - org.apache.flink.runtime.highavailability中的接口
Factory interface for HighAvailabilityServices.
HighAvailabilityServicesUtils - org.apache.flink.runtime.highavailability中的类
Utils class to instantiate HighAvailabilityServices implementations.
HighAvailabilityServicesUtils() - 类 的构造器org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
HighAvailabilityServicesUtils.AddressResolution - org.apache.flink.runtime.highavailability中的枚举
Enum specifying whether address resolution should be tried or not when creating the HighAvailabilityServices.
histogram(int, H) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
histogram(String, H) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
histogram(String, H) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
histogram(int, H) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
HistogramDump(QueryScopeInfo, String, long, long, double, double, double, double, double, double, double, double, double) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
HistoryServerArchivist - org.apache.flink.runtime.dispatcher中的接口
Writer for an AccessExecutionGraph.
HOST_OPTION - 类 中的静态变量org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
 
hostname() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
hostname() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
HTTP_ATTRIBUTE_REQUEST - 类 中的静态变量org.apache.flink.runtime.rest.FileUploadHandler
 
HTTP_DATE_FORMAT - 类 中的静态变量org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Date format for HTTP.
HttpMethodWrapper - org.apache.flink.runtime.rest中的枚举
This class wraps netty's HttpMethods into an enum, allowing us to use them in switches.

I

id - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
The ID of the underlying channel.
ID(File, int) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
ID(File, int, Random) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
IllegalExecutionStateException - org.apache.flink.runtime.executiongraph中的异常错误
A special IllegalStateException indicating a mismatch in the expected and actual ExecutionState of an Execution.
IllegalExecutionStateException(ExecutionState, ExecutionState) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
IllegalExecutionStateException(Execution, ExecutionState, ExecutionState) - 异常错误 的构造器org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
immutableEntries() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
includeAlternativeOperatorIDs(Map<OperatorID, ExecutionJobVertex>) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includeSerializedAccumulatorsParameter - 类 中的变量org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
 
increaseBackoff() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Increases the current backoff and returns whether the operation was successful.
increaseBuffersInBacklog(BufferConsumer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Increases the number of non-event buffers by one after adding a non-event buffer into this subpartition.
increment() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Increments the reference count and returns whether it was successful.
IncrementalKeyedStateHandle - org.apache.flink.runtime.state中的接口
Common interface to all incremental KeyedStateHandle.
IncrementalLocalKeyedStateHandle - org.apache.flink.runtime.state中的类
State handle for local copies of IncrementalRemoteKeyedStateHandle.
IncrementalLocalKeyedStateHandle(UUID, long, DirectoryStateHandle, KeyGroupRange, StreamStateHandle, Set<StateHandleID>) - 类 的构造器org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
IncrementalRemoteKeyedStateHandle - org.apache.flink.runtime.state中的类
The handle to states of an incremental snapshot.
IncrementalRemoteKeyedStateHandle(UUID, KeyGroupRange, long, Map<StateHandleID, StreamStateHandle>, Map<StateHandleID, StreamStateHandle>, StreamStateHandle) - 类 的构造器org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
incrementIterationCounter() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
index - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultSubpartition
The index of the subpartition at the parent partition.
IndexedSortable - org.apache.flink.runtime.operators.sort中的接口
 
IndexedSorter - org.apache.flink.runtime.operators.sort中的接口
 
INDIVIDUAL_RESTART_STRATEGY_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartIndividualStrategy
INF_TIMEOUT - 类 中的静态变量org.apache.flink.runtime.rpc.RpcUtils
HACK: Set to 21474835 seconds, Akka's maximum delay (Akka 2.4.20).
inFirstIteration() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
INFO_CATEGORY_JM - 类 中的静态变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Categories to be returned by QueryScopeInfo.getCategory() to avoid instanceof checks.
INFO_CATEGORY_JOB - 类 中的静态变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_OPERATOR - 类 中的静态变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_TASK - 类 中的静态变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_TM - 类 中的静态变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
InfoMessage - org.apache.flink.runtime.clusterframework.messages中的类
A simple informational message sent by the resource master to the client.
InfoMessage(String) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
InfoMessage(String, Date) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
InfoMessage - org.apache.flink.runtime.messages.webmonitor中的接口
Abstract base interface of all info messages exchanged between the JobManager an for example the runtime monitor.
InfoMessageListenerRpcGateway - org.apache.flink.runtime.resourcemanager中的接口
A gateway to listen for info messages from ResourceManager
initBroadcastInputReaders() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Creates the record readers for the extra broadcast inputs as configured by TaskConfig.getNumBroadcastInputs().
initBroadcastInputsSerializers(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Creates all the serializers and iterators for the broadcast inputs.
InitializationTypeConflictException - 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<?>) - 异常错误 的构造器org.apache.flink.runtime.broadcast.InitializationTypeConflictException
 
initialize() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
initialize() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationIntermediateTask
 
initialize() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationTailTask
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
initialize() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
initialize() - 接口 中的方法org.apache.flink.runtime.operators.ResettableDriver
 
initialize() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Initializes the framework specific components.
initialize() - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
initializeBroadcastVariable(Iterable<T>) - 类 中的方法org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
initializeBufferMetrics(Task) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
Initialize Buffer Metrics for a task.
initializeHandlers(CompletableFuture<String>) - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
 
initializeHandlers(CompletableFuture<String>) - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
initializeLocationForCheckpoint(long) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Initializes a storage location for new checkpoint with the given ID.
initializeLocationForCheckpoint(long) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
initializeLocationForCheckpoint(long) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
initializeLocationForSavepoint(long, String) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Initializes a storage location for new savepoint with the given ID.
initializeLocationForSavepoint(long, String) - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates a file system based storage location for a savepoint.
initializeOnMaster(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.InputFormatVertex
 
initializeOnMaster(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master when the job starts.
initializeOnMaster(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
initializeServices(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
initialPartitionBuffersCount - 类 中的变量org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
initInputReaders() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Creates the record readers for the number of inputs as defined by BatchTask.getNumTaskInputs().
initInputsSerializersAndComparators(int, int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Creates all the serializers and comparators.
initLocalStrategies(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
NOTE: This method must be invoked after the invocation of #initInputReaders() and #initInputSerializersAndComparators(int)!
initOutputs() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationHeadTask
 
initOutputs() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Creates a writer for each output.
initOutputs(AbstractInvokable, ClassLoader, TaskConfig, List<ChainedDriver<?, ?>>, List<RecordWriter<?>>, ExecutionConfig, Map<String, Accumulator<?, ?>>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Creates a writer for each output.
initStub(Class<? super S>) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
initTable(int, byte) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
InMemoryPartition<T> - org.apache.flink.runtime.operators.hash中的类
In-memory partition with overflow buckets for CompactingHashTable
InMemoryPartition(TypeSerializer<T>, int, ListMemorySegmentSource, int, int) - 类 的构造器org.apache.flink.runtime.operators.hash.InMemoryPartition
Creates a new partition, in memory, with one buffer.
InMemorySorter<T> - org.apache.flink.runtime.operators.sort中的接口
 
InMemorySorterFactory<T> - org.apache.flink.runtime.operators.sort中的接口
Factory for InMemorySorter.
InPlaceMutableHashTable<T> - org.apache.flink.runtime.operators.hash中的类
This hash table supports updating elements.
InPlaceMutableHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
InPlaceMutableHashTable.EntryIterator - org.apache.flink.runtime.operators.hash中的类
WARNING: Doing any other operation on the table invalidates the iterator!
InPlaceMutableHashTable.HashTableProber<PT> - org.apache.flink.runtime.operators.hash中的类
A prober for accessing the table.
InPlaceMutableHashTable.ReduceFacade - 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() - 类 中的静态方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
inProgress() - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
inProgress() - 类 中的静态方法org.apache.flink.runtime.rest.messages.queue.QueueStatus
 
input - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
input - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
input - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
InputChannel - org.apache.flink.runtime.io.network.partition.consumer中的类
An input channel consumes a single ResultSubpartitionView.
InputChannel(SingleInputGate, int, ResultPartitionID, int, int, Counter, Counter) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
InputChannel.BufferAndAvailability - org.apache.flink.runtime.io.network.partition.consumer中的类
A combination of a Buffer and a flag indicating availability of further buffers, and the backlog length indicating how many non-event buffers are available in the subpartition.
InputChannelDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
Deployment descriptor for a single input channel instance.
InputChannelDeploymentDescriptor(ResultPartitionID, ResultPartitionLocation) - 类 的构造器org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
InputChannelID - org.apache.flink.runtime.io.network.partition.consumer中的类
Identifier for input channels.
InputChannelID() - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
InputChannelID(long, long) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
InputChannelID(AbstractID) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
inputComparators - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The comparators for the central driver.
InputEndOfStreamException - org.apache.flink.runtime.checkpoint.decline中的异常错误
Exception indicating that a checkpoint was declined because one of the input stream reached its end before the alignment was complete.
InputEndOfStreamException() - 异常错误 的构造器org.apache.flink.runtime.checkpoint.decline.InputEndOfStreamException
 
InputFormatVertex - org.apache.flink.runtime.jobgraph中的类
 
InputFormatVertex(String) - 类 的构造器org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID) - 类 的构造器org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - 类 的构造器org.apache.flink.runtime.jobgraph.InputFormatVertex
 
inputGate - 类 中的变量org.apache.flink.runtime.io.network.api.reader.AbstractReader
The input gate to read from.
inputGate - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
InputGate - org.apache.flink.runtime.io.network.partition.consumer中的接口
An input gate consumes one or more partitions of a single produced intermediate result.
InputGateDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
Deployment descriptor for a single input gate instance.
InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, InputChannelDeploymentDescriptor[]) - 类 的构造器org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
InputGateListener - org.apache.flink.runtime.io.network.partition.consumer中的接口
Listener interface implemented by consumers of InputGate instances that want to be notified of availability of buffer or event instances.
InputGateMetrics - org.apache.flink.runtime.io.network.partition.consumer中的类
Collects metrics of an input gate.
inputIterators - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The inputs reader, wrapped in an iterator.
inputReaders - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The input readers of this task.
inputs - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The inputs to the operator.
inputSerializers - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The serializers for the input data type.
InputSplitProvider - 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 - org.apache.flink.runtime.jobgraph.tasks中的异常错误
 
InputSplitProviderException(String) - 异常错误 的构造器org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputSplitProviderException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputSplitProviderException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputViewIterator<E> - org.apache.flink.runtime.io.disk中的类
 
InputViewIterator(DataInputView, TypeSerializer<E>) - 类 的构造器org.apache.flink.runtime.io.disk.InputViewIterator
 
insert(T) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
insert(T) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
 
insert(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Inserts the given record into the hash table.
insertAfterNoMatch(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
This method can be called after getMatchFor returned null.
insertIntoBuildBuffer(BT) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
Inserts the given object into the current buffer.
insertIntoProbeBuffer(PT) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
Inserts the given record into the probe side buffers.
insertIntoTable(BT, int) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
insertOrReplaceRecord(T) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
insertOrReplaceRecord(T) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
Replaces record in hash table if record already present or append record if not.
insertOrReplaceRecord(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Searches the hash table for a record with the given key.
install() - 类 中的方法org.apache.flink.runtime.security.modules.HadoopModule
 
install() - 类 中的方法org.apache.flink.runtime.security.modules.JaasModule
 
install() - 接口 中的方法org.apache.flink.runtime.security.modules.SecurityModule
Install the security module.
install() - 类 中的方法org.apache.flink.runtime.security.modules.ZooKeeperModule
 
install(SecurityConfiguration) - 类 中的静态方法org.apache.flink.runtime.security.SecurityUtils
Installs a process-wide security configuration.
installAsShutdownHook(Logger) - 类 中的静态方法org.apache.flink.runtime.util.JvmShutdownSafeguard
Installs the safeguard shutdown hook.
installAsShutdownHook(Logger, long) - 类 中的静态方法org.apache.flink.runtime.util.JvmShutdownSafeguard
Installs the safeguard shutdown hook.
installSecurityContext(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
instance() - 类 中的静态方法org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
The singleton instance of the serializer
Instance - org.apache.flink.runtime.instance中的类
An instance represents a TaskManager registered at a JobManager and ready to receive work.
Instance(TaskManagerGateway, TaskManagerLocation, InstanceID, HardwareDescription, int) - 类 的构造器org.apache.flink.runtime.instance.Instance
Constructs an instance reflecting a registered TaskManager.
INSTANCE - 类 中的静态变量org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
The singleton instance of this event.
INSTANCE - 类 中的静态变量org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
The singleton instance of this event.
INSTANCE - 类 中的静态变量org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
 
instance() - 类 中的静态方法org.apache.flink.runtime.iterative.concurrent.BlockingBackChannelBroker
Retrieve singleton instance.
instance() - 类 中的静态方法org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
Retrieve singleton instance.
instance() - 类 中的静态方法org.apache.flink.runtime.iterative.concurrent.SolutionSetBroker
Retrieve the singleton instance.
instance() - 类 中的静态方法org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrierBroker
 
instance() - 类 中的静态方法org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatchBroker
Retrieve the singleton instance.
INSTANCE - 类 中的静态变量org.apache.flink.runtime.iterative.event.TerminationEvent
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.state.VoidNamespace
The singleton instance
INSTANCE - 类 中的静态变量org.apache.flink.runtime.state.VoidNamespaceSerializer
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
INSTANCE - 类 中的静态变量org.apache.flink.runtime.util.FatalExitExceptionHandler
 
instanceDied(Instance) - 接口 中的方法org.apache.flink.runtime.instance.InstanceListener
Called when an instance died.
instanceDied(Instance) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
InstanceDiedException - 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) - 异常错误 的构造器org.apache.flink.runtime.instance.InstanceDiedException
 
InstanceID - org.apache.flink.runtime.instance中的类
Class for statistically unique instance IDs.
InstanceID() - 类 的构造器org.apache.flink.runtime.instance.InstanceID
 
InstanceID(byte[]) - 类 的构造器org.apache.flink.runtime.instance.InstanceID
 
InstanceListener - org.apache.flink.runtime.instance中的接口
Classes implementing the InstanceListener interface can be notified about the availability disappearance of instances.
InstanceManager - org.apache.flink.runtime.instance中的类
Simple manager that keeps track of which TaskManager are available and alive.
InstanceManager() - 类 的构造器org.apache.flink.runtime.instance.InstanceManager
Creates an new instance manager.
instantiateJobManagerMetricGroup(MetricRegistry, String, Optional<Time>) - 类 中的静态方法org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateStatusMetrics(MetricGroup) - 类 中的静态方法org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateSystemMetrics(MetricGroup, Time) - 类 中的静态方法org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
 
instantiateTaskManagerMetricGroup(MetricRegistry, TaskManagerLocation, NetworkEnvironment, Optional<Time>) - 类 中的静态方法org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateUserCode(TaskConfig, ClassLoader, Class<? super T>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Instantiates a user code class from is definition in the task configuration.
IntArrayList - org.apache.flink.runtime.util中的类
Minimal implementation of an array-backed list of ints
IntArrayList(int) - 类 的构造器org.apache.flink.runtime.util.IntArrayList
 
IntermediateDataSet - 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) - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
IntermediateDataSetID - org.apache.flink.runtime.jobgraph中的类
 
IntermediateDataSetID() - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates an new random intermediate data set ID.
IntermediateDataSetID(AbstractID) - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates a new intermediate data set ID with the bytes of the given ID.
IntermediateDataSetID(UUID) - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates a new intermediate data set ID with the bytes of the given UUID.
IntermediateResult - org.apache.flink.runtime.executiongraph中的类
 
IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType) - 类 的构造器org.apache.flink.runtime.executiongraph.IntermediateResult
 
IntermediateResultPartition - org.apache.flink.runtime.executiongraph中的类
 
IntermediateResultPartition(IntermediateResult, ExecutionVertex, int) - 类 的构造器org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
IntermediateResultPartitionID - org.apache.flink.runtime.jobgraph中的类
 
IntermediateResultPartitionID() - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
Creates an new random intermediate result partition ID.
IntermediateResultPartitionID(long, long) - 类 的构造器org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
InternalAggregatingState<K,N,IN,SV,OUT> - org.apache.flink.runtime.state.internal中的接口
The peer to the AggregatingState in the internal state type hierarchy.
InternalAppendingState<K,N,IN,SV,OUT> - org.apache.flink.runtime.state.internal中的接口
The peer to the AppendingState in the internal state type hierarchy.
internalDeregisterApplication(ApplicationStatus, String) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
The framework specific code to deregister the application.
internalDeregisterApplication(ApplicationStatus, String) - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
InternalFoldingState<K,N,T,ACC> - org.apache.flink.runtime.state.internal中的接口
已过时。
will be removed in a future version
internalHandleException(IOException) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Internally handles an exception and makes sure that this method returns without a problem.
InternalKeyContext<K> - org.apache.flink.runtime.state.heap中的接口
This interface is the current context of a keyed state.
InternalKvState<K,N,V> - 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> - org.apache.flink.runtime.state.internal中的接口
The state entry visitor which supports remove and update of the last returned entries.
InternalListState<K,N,T> - org.apache.flink.runtime.state.internal中的接口
The peer to the ListState in the internal state type hierarchy.
InternalMapState<K,N,UK,UV> - org.apache.flink.runtime.state.internal中的接口
The peer to the MapState in the internal state type hierarchy.
InternalMergingState<K,N,IN,SV,OUT> - org.apache.flink.runtime.state.internal中的接口
The peer to the MergingState in the internal state type hierarchy.
internalNioBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
InternalPriorityQueue<T> - org.apache.flink.runtime.state中的接口
Interface for collection that gives in order access to elements w.r.t their priority.
InternalReducingState<K,N,T> - org.apache.flink.runtime.state.internal中的接口
The peer to the ReducingState in the internal state type hierarchy.
InternalValueState<K,N,T> - org.apache.flink.runtime.state.internal中的接口
The peer to the ValueState in the internal state type hierarchy.
invalidateCurrentSchemaSerializerAccess() - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
Invalidates access to the current schema serializer.
inView - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
inView - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
invoke() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
invoke() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Starts the execution.
invoke() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
The main work method.
invoke() - 类 中的方法org.apache.flink.runtime.operators.DataSinkTask
 
invoke() - 类 中的方法org.apache.flink.runtime.operators.DataSourceTask
 
invoke(Object, Method, Object[]) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
invokeRegistration(G, F, long) - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistration
 
IO_CURRENT_INPUT_1_WATERMARK - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_CURRENT_INPUT_2_WATERMARK - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_CURRENT_INPUT_WATERMARK - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_CURRENT_OUTPUT_WATERMARK - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_IN - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_IN_LOCAL - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_IN_LOCAL_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_IN_REMOTE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_IN_REMOTE_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_OUT - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BUFFERS_OUT_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_OUT - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_OUT_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_IN - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_IN_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_OUT - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_OUT_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
IOManager - org.apache.flink.runtime.io.disk.iomanager中的类
The facade for the provided I/O manager services.
IOManager(String[]) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.IOManager
Constructs a new IOManager.
ioManager - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The I/O manager used to instantiate writers for the spilled partitions.
ioManager - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
IOManager.IOMode - org.apache.flink.runtime.io.disk.iomanager中的枚举
 
IOManagerAsync - org.apache.flink.runtime.io.disk.iomanager中的类
A version of the IOManager that uses asynchronous I/O.
IOManagerAsync() - 类 的构造器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) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manager, writing file to the given directory.
IOManagerAsync(String[]) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manager, writing file round robin across the given directories.
IOMetrics - org.apache.flink.runtime.executiongraph中的类
An instance of this class represents a snapshot of the io-related metrics of a single task.
IOMetrics(Meter, Meter, Meter, Meter, Meter) - 类 的构造器org.apache.flink.runtime.executiongraph.IOMetrics
 
IOMetrics(long, long, long, long, long, double, double, double, double, double) - 类 的构造器org.apache.flink.runtime.executiongraph.IOMetrics
 
IOMetricsInfo - org.apache.flink.runtime.rest.messages.job.metrics中的类
IO metrics information.
IOMetricsInfo(long, boolean, long, boolean, long, boolean, long, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
ioMode() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
isAcknowledgedBy(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isActive(JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isAlive() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
isAlive() - 类 中的方法org.apache.flink.runtime.instance.Slot
Checks of the slot is still alive, i.e. in state Slot.ALLOCATED_AND_ALIVE.
isAlive() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
True if the slot is alive and has not been released.
isAlive() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
isAllocated(JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isAllocated(int, JobID, AllocationID) - 类 中的方法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() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns whether this execution graph was archived.
isArchived() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
isArchived() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isAssigned() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Checks whether the location of this constraint has been assigned.
isAssigned() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
isAssignedAndAlive() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
已过时。
Should only be called by legacy code (if using Scheduler)
isAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
Checks whether this reader is available or not.
isAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
isBasicType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
isBlocking() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isBounded() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
Whether this partition uses a limited number of (network) buffers or not.
isBroadcast() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelector
Returns whether the channel selector always selects all the output channels.
isBroadcast() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
isBroadcast() - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputEmitter
 
isBuffer() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
isBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns whether this buffer represents a buffer or an event.
isBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
isBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
isBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
isBuffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
isBufferConsumed() - 枚举 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
 
isBytesReadComplete() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
isBytesWrittenComplete() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
isCanceled() - 类 中的方法org.apache.flink.runtime.instance.Slot
Checks of the slot has been cancelled.
isCanceled() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistration
Checks if the registration was canceled.
isCanceledOrFailed() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Checks whether the task has failed, is canceled, or is being canceled at the moment.
isCancelJob() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
isCancelled() - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
isCancelled() - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
isCheckpointingEnabled() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Checks if the checkpointing was enabled for this job graph
isClosed() - 类 中的方法org.apache.flink.runtime.blob.BlobClient
 
isClosed() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
isClosed() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
 
isClosed() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
isClosed() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Checks whether the channel has been closed.
isClosed() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.RequestQueue
Checks whether this request queue is closed.
isClosed() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
isClosed() - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
isClosed() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
isClosed() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
isClosed() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
isClosed() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
Checks whether the stream is closed.
isClosed() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
isCompacted() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
isCompleted() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has completed successfully.
isConnected() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
isConsumable() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
isConverged(int, LongValue) - 类 中的方法org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
isCreditBased() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
isCreditBasedEnabled() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
isDefaultReference() - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
Returns true, if this object is the default reference.
isDefaultVersion() - 枚举 中的方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
Returns whether this version is the default REST API version.
isDestroyed() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Checks whether this buffer pool has been destroyed.
isDestroyed() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns whether the buffer provider has been destroyed.
isDestroyed() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
isDirect() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
isDiscarded() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
Returns whether the checkpoint has been discarded.
isDiscarded() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isDiscarded() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
isDisposed() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Returns whether the reference count has reached the disposed state.
isDone() - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
isDone() - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
isEmpty() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
isEmpty() - 类 中的方法org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
isEmpty() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
isEmpty() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Checks whether the buffer is empty.
isEmpty() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Checks whether the buffer is empty.
isEmpty() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Checks whether the buffer is empty.
isEmpty() - 类 中的方法org.apache.flink.runtime.state.ChainedStateHandle
Check if there are any states handles present.
isEmpty() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
isEmpty() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
isEmpty() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Returns whether this StateTable is empty.
isEmpty() - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Check if the set contains any elements.
isEmpty() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isEmpty() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
isEmpty() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
isEmpty() - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
isEndOfSuperstep() - 类 中的方法org.apache.flink.runtime.iterative.task.SyncEventHandler
 
isEvent(Buffer, Class<?>) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
Identifies whether the given buffer encodes the given event.
isEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
isExactlyOnce() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
isFailed() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has failed.
isFailure() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
isFinished() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
isFinished() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
isFinished() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
Returns whether the reader has consumed the input.
isFinished() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
isFinished() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
Checks whether the BufferBuilder has already been finished.
isFinished() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
isFinished() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
isFinished() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
isFree() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isFull() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
isFullBuffer() - 枚举 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the target buffer is full after the serialization process.
isFullRecord() - 枚举 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
 
isFullRecord() - 枚举 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the full record was serialized and completely written to a target buffer.
isFullyAcknowledged() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isGloballyTerminalState() - 枚举 中的方法org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is globally terminal.
isHighAvailabilityModeActivated(Configuration) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Returns true if the defined recovery mode supports high availability.
isIdle() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
isIdReference() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
 
isImmutableType() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
isImmutableType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
isInMemory() - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
Checks whether this partition is in memory or spilled.
isInProgress() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint is in progress.
isInputAsynchronouslyMaterialized(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
isInputCached(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
isInputResettable(int) - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
isInputResettable(int) - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
isInputResettable(int) - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
isInputResettable(int) - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
isInputResettable(int) - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
isInputResettable(int) - 接口 中的方法org.apache.flink.runtime.operators.ResettableDriver
 
isInputVertex() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
isInternalSSLEnabled(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Checks whether SSL for internal communication (rpc, data transport, blob server) is enabled.
isIterativeInputGate(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
isKeyGroupAlreadyFinished(int) - 类 中的方法org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns true if the key group is already completely written and immutable.
isKeyGroupAlreadyStarted(int) - 类 中的方法org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns true, if the key group with the given id was already started.
isKeyType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
isLeader() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
isLocal() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isLocalRecoveryEnabled() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryConfig
 
isLocalRecoveryEnabled() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
isMandatory() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Returns whether this parameter must be resolved for the request.
isMatching(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
Check whether required resource profile can be matched.
isMatchingRequirement(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
Check whether required resource profile can be matched by this slot.
isMaterializing() - 枚举 中的方法org.apache.flink.runtime.operators.DamBehavior
Checks whether this enumeration represents some form of materialization, either with a full dam or without.
isMaterializing() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
isMaxParallelismConfigured() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
isMoreAvailable() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
isNetworkStrategy() - 枚举 中的方法org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
isNullOrEmpty(ChainedStateHandle<?>) - 类 中的静态方法org.apache.flink.runtime.state.ChainedStateHandle
 
isNumBytesInLocalComplete() - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isNumBytesInRemoteComplete() - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isNumBytesOutComplete() - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isNumRecordsInComplete() - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isNumRecordsOutComplete() - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isOutputVertex() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
isPeriodicCheckpointingConfigured() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Returns whether periodic checkpointing has been configured.
isPipelined() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isPreAllocated() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Checks whether this memory manager pre-allocates the memory.
isPreAllocateMemory() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
isProperlyShutDown() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Utility method to check whether the IO manager has been properly shut down.
isProperlyShutDown() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Utility method to check whether the IO manager has been properly shut down.
isQueuedSchedulingAllowed() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isRecordsReadComplete() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
isRecordsWrittenComplete() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
isRecycled() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns whether this buffer has been recycled or not.
isRecycled() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
isRecycled() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
isRecycled() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
isRegistered(InstanceID) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
isRegistered(ResourceID) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
isRegisteredAsAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
isReleased() - 类 中的方法org.apache.flink.runtime.instance.Slot
Checks of the slot has been released.
isReleased() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
isReleased() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
isReleased() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Whether this partition is released.
isReleased() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
isReleased() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
isReleasing() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isRemote() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isResolved() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Returns whether this parameter has been resolved.
isResolved() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameters
Returns whether all mandatory parameters have been resolved.
isRestored() - 类 中的方法org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
Returns true if this was created for a restored operator, false otherwise.
isRestored() - 接口 中的方法org.apache.flink.runtime.state.ManagedInitializationContext
Returns true, if state was restored from the snapshot of a previous execution.
isRestored() - 类 中的方法org.apache.flink.runtime.state.StateInitializationContextImpl
 
isRestSSLAuthenticationEnabled(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Checks whether mutual SSL authentication for the external REST endpoint is enabled.
isRestSSLEnabled(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
Checks whether SSL for the external REST endpoint is enabled.
isRootAndEmpty() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
Checks whether this slot is a root slot that has not yet added any child slots.
isRunning() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
Checks if the mini cluster was started and is running.
isRunning() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Checks whether this thread is still alive.
isRunningInExpectedThread(Thread) - 类 中的静态方法org.apache.flink.runtime.rpc.MainThreadValidatorUtil
Returns true iff the current thread is equals to the provided expected thread and logs violations.
isSavepoint() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
Returns whether the checkpoint properties describe a standard savepoint.
isSavepoint() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
isSavepoint() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
isShutdown() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
Tests whether the BLOB server has been requested to shut down.
isShutdown() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
isShutDown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
isShutdown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
isShutdown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
isShutdown() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
isShutdown() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Checks whether the MemoryManager has been shut down.
isShutdown() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
Returns whether this registry has been shutdown.
isSlotFree(int) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the task slot with the given index is free.
isSnapshotCompleted() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
Returns true if the snapshot is marked as completed.
isSolutionSetUnmanaged() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
isSolutionSetUpdate - 类 中的变量org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isStarted() - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Checks whether the service has been started.
isStillAlive(long, long) - 类 中的方法org.apache.flink.runtime.instance.Instance
Checks whether the last heartbeat occurred within the last n milliseconds before the given timestamp now.
isStoppable() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns whether the job for this execution graph is stoppable.
isStoppable() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
isStoppable() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isStoppable() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
isStoppable() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
isSuccess() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
isSuccess() - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
Returns true if the job finished successfully.
isSynchronous() - 枚举 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
 
isTerminal() - 枚举 中的方法org.apache.flink.runtime.execution.ExecutionState
 
isTerminalState() - 枚举 中的方法org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is locally terminal.
isTtlStateSerializer(TypeSerializer<?>) - 类 中的静态方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
isTupleType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
isUnknown() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isUsingAsynchronousSnapshots() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets whether the key/value data structures are asynchronously snapshotted.
isUsingAsynchronousSnapshots() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackend
Gets whether the key/value data structures are asynchronously snapshotted.
isUsingKeyGroupCompression() - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
isValid(K, UUID) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
isValidTimeout(AllocationID, UUID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the timeout with ticket is valid for the given allocation id.
isWaitResultConsumedBeforeRelease() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
isWorksetIteration - 类 中的变量org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isWorksetUpdate - 类 中的变量org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isWritable() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
isWritable(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
isZkSaslDisable() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 
isZooKeeperRecoveryMode(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Returns whether HighAvailabilityMode.ZOOKEEPER is configured.
IterationAggregatorBroker - org.apache.flink.runtime.iterative.concurrent中的类
IterationAggregatorBroker() - 类 的构造器org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
 
IterationEventWithAggregators - org.apache.flink.runtime.iterative.event中的类
Base class for iteration TaskEvent transmitting operator aggregators.
IterationEventWithAggregators() - 类 的构造器org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationEventWithAggregators(String, Value) - 类 的构造器org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationEventWithAggregators(Map<String, Aggregator<?>>) - 类 的构造器org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT> - org.apache.flink.runtime.iterative.task中的类
The head is responsible for coordinating an iteration and can run a Driver inside.
IterationHeadTask(Environment) - 类 的构造器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> - org.apache.flink.runtime.iterative.task中的类
An intermediate iteration task, which runs a Driver inside.
IterationIntermediateTask(Environment) - 类 的构造器org.apache.flink.runtime.iterative.task.IterationIntermediateTask
Create an Invokable task and set its environment.
IterationSynchronizationSinkTask - org.apache.flink.runtime.iterative.task中的类
The task responsible for synchronizing all iteration heads, implemented as an output task.
IterationSynchronizationSinkTask(Environment) - 类 的构造器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> - org.apache.flink.runtime.iterative.task中的类
An iteration tail, which runs a driver inside.
IterationTailTask(Environment) - 类 的构造器org.apache.flink.runtime.iterative.task.IterationTailTask
Create an Invokable task and set its environment.
iterativeBroadcastInputs - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The indices of the iterative broadcast inputs.
iterativeInputs - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The indices of the iterative inputs.
iterator() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
iterator() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
iterator() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
iterator() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
 
iterator() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
 
iterator - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The iterator to be returned by the sort-merger.
iterator() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingIterable
 
iterator() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
Returns an iterator over the elements in this queue.
iterator() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
iterator() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
iterator() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
iterator() - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Iterator over all elements, no order guaranteed.
iterator() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
iterator() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
iterator() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotReport
 
iterator() - 类 中的方法org.apache.flink.runtime.util.EmptyIterator
 
iterator() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
iterator() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
iterator() - 类 中的方法org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
iterator() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
iterator() - 类 中的方法org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
iterator() - 类 中的方法org.apache.flink.runtime.util.SingleElementIterator
 
iterator1 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iterator2 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iteratorException - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The exception that is set, if the iterator cannot be created.
iteratorLock - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The monitor which guards the iterator field.

J

JaasModule - org.apache.flink.runtime.security.modules中的类
Responsible for installing a process-wide JAAS configuration.
JaasModule(SecurityConfiguration) - 类 的构造器org.apache.flink.runtime.security.modules.JaasModule
 
JaasModuleFactory - org.apache.flink.runtime.security.modules中的类
JaasModuleFactory() - 类 的构造器org.apache.flink.runtime.security.modules.JaasModuleFactory
 
JACKSON_FACTORY - 类 中的静态变量org.apache.flink.runtime.rest.handler.legacy.JsonFactory
The singleton Jackson JSON factory.
jarFileNames - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
JMTMRegistrationSuccess - org.apache.flink.runtime.jobmaster中的类
Message indicating a successful JobMaster and TaskExecutor registration.
JMTMRegistrationSuccess(ResourceID) - 类 的构造器org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
JOB_GRAPH_FILE_PATH - 类 中的静态变量org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
 
JOB_MANAGER_NAME - 类 中的静态变量org.apache.flink.runtime.jobmaster.JobMaster
Default names for Flink's distributed components.
JobAccumulator() - 类 的构造器org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.JobAccumulator
 
JobAccumulatorsHandler - org.apache.flink.runtime.rest.handler.job中的类
Request handler that returns the aggregated accumulators of a job.
JobAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobAccumulatorsInfo, JobAccumulatorsMessageParameters>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
 
JobAccumulatorsHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobAccumulatorsHandler.
JobAccumulatorsInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobAccumulatorsHandler.
JobAccumulatorsInfo(List<JobAccumulatorsInfo.JobAccumulator>, List<JobAccumulatorsInfo.UserTaskAccumulator>, Map<String, SerializedValue<OptionalFailure<Object>>>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
JobAccumulatorsInfo.JobAccumulator - org.apache.flink.runtime.rest.messages中的类
Json serializer for the JobAccumulatorsInfo.
JobAccumulatorsInfo.UserTaskAccumulator - org.apache.flink.runtime.rest.messages中的类
Json serializer for the JobAccumulatorsInfo.
JobAccumulatorsMessageParameters - org.apache.flink.runtime.rest.messages中的类
Request parameter for job accumulator's handler JobAccumulatorsHandler.
JobAccumulatorsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
 
JobCancellationException - org.apache.flink.runtime.client中的异常错误
An exception which is thrown by the JobClient if a job is aborted as a result of a user cancellation.
JobCancellationException(JobID, String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobCancellationException
 
JobCheckpointingSettings - org.apache.flink.runtime.jobgraph.tasks中的类
The JobCheckpointingSettings are attached to a JobGraph and describe the settings for the asynchronous checkpoints of the JobGraph, such as interval, and which vertices need to participate.
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>) - 类 的构造器org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>, SerializedValue<MasterTriggerRestoreHook.Factory[]>) - 类 的构造器org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobClusterEntrypoint - org.apache.flink.runtime.entrypoint中的类
Base class for per-job cluster entry points.
JobClusterEntrypoint(Configuration) - 类 的构造器org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
JobConfigHandler - org.apache.flink.runtime.rest.handler.job中的类
Handler serving the job configuration.
JobConfigHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobConfigHandler
 
JobConfigHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobConfigHandler.
JobConfigInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobConfigHandler.
JobConfigInfo(JobID, String, JobConfigInfo.ExecutionConfigInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.JobConfigInfo
 
JobConfigInfo.Deserializer - org.apache.flink.runtime.rest.messages中的类
Json deserializer for the JobConfigInfo.
JobConfigInfo.ExecutionConfigInfo - org.apache.flink.runtime.rest.messages中的类
Nested class to encapsulate the execution configuration.
JobConfigInfo.Serializer - org.apache.flink.runtime.rest.messages中的类
Json serializer for the JobConfigInfo.
JobDetails - org.apache.flink.runtime.messages.webmonitor中的类
An actor message with a detailed overview of the current status of a job.
JobDetails(JobID, String, long, long, long, JobStatus, long, int[], int) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobDetails
 
JobDetails.JobDetailsDeserializer - org.apache.flink.runtime.messages.webmonitor中的类
 
JobDetails.JobDetailsSerializer - org.apache.flink.runtime.messages.webmonitor中的类
 
JobDetailsDeserializer() - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsDeserializer
 
JobDetailsHandler - org.apache.flink.runtime.rest.handler.job中的类
Handler returning the details for the specified job.
JobDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobDetailsInfo, JobMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
 
JobDetailsHeaders - org.apache.flink.runtime.rest.messages.job中的类
Message headers for the JobDetailsHandler.
JobDetailsInfo - org.apache.flink.runtime.rest.messages.job中的类
Details about a job.
JobDetailsInfo(JobID, String, boolean, JobStatus, long, long, long, long, Map<JobStatus, Long>, Collection<JobDetailsInfo.JobVertexDetailsInfo>, Map<ExecutionState, Integer>, String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
JobDetailsInfo.JobVertexDetailsInfo - org.apache.flink.runtime.rest.messages.job中的类
Detailed information about a job vertex.
JobDetailsSerializer() - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsSerializer
 
JobDispatcherFactory - org.apache.flink.runtime.dispatcher中的类
JobDispatcherFactory(JobGraphRetriever) - 类 的构造器org.apache.flink.runtime.dispatcher.JobDispatcherFactory
 
JobDispatcherResourceManagerComponentFactory - org.apache.flink.runtime.entrypoint.component中的类
DispatcherResourceManagerComponentFactory for a JobDispatcherResourceManagerComponent.
JobDispatcherResourceManagerComponentFactory(ResourceManagerFactory<?>, JobGraphRetriever) - 类 的构造器org.apache.flink.runtime.entrypoint.component.JobDispatcherResourceManagerComponentFactory
 
JobEdge - org.apache.flink.runtime.jobgraph中的类
This class represent edges (communication channels) in a job graph.
JobEdge(IntermediateDataSet, JobVertex, DistributionPattern) - 类 的构造器org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge, that connects an intermediate result to a consumer task.
JobEdge(IntermediateDataSetID, JobVertex, DistributionPattern) - 类 的构造器org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge that refers to an intermediate result via the Id, rather than directly through the intermediate data set structure.
JobException - org.apache.flink.runtime中的异常错误
Indicates that a job has failed.
JobException(String) - 异常错误 的构造器org.apache.flink.runtime.JobException
 
JobException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.JobException
 
JobExceptionsHandler - org.apache.flink.runtime.rest.handler.job中的类
Handler serving the job exceptions.
JobExceptionsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobExceptionsInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
 
JobExceptionsHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobExceptionsHandler.
JobExceptionsInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobExceptionsHandler.
JobExceptionsInfo(String, Long, List<JobExceptionsInfo.ExecutionExceptionInfo>, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
JobExceptionsInfo.ExecutionExceptionInfo - org.apache.flink.runtime.rest.messages中的类
Nested class to encapsulate the task execution exception.
JobExecutionException - org.apache.flink.runtime.client中的异常错误
This exception is the base exception for all exceptions that denote any failure during the execution of a job.
JobExecutionException(JobID, String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobExecutionException
Constructs a new job execution exception.
JobExecutionException(JobID, String) - 异常错误 的构造器org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionException(JobID, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionResultHandler - org.apache.flink.runtime.rest.handler.job中的类
Returns the JobExecutionResult for a given JobID.
JobExecutionResultHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobExecutionResultHandler
 
JobExecutionResultHeaders - org.apache.flink.runtime.rest.messages.job中的类
JobExecutionResultHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
 
JobExecutionResultResponseBody - org.apache.flink.runtime.rest.messages.job中的类
ResponseBody that carries a QueueStatus and a JobResult.
JobExecutionResultResponseBody(QueueStatus, JobResult) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
JobExecutor - org.apache.flink.runtime.minicluster中的接口
Interface for JobGraph executors.
JobExecutorService - org.apache.flink.runtime.minicluster中的接口
Interface to control JobExecutor.
jobFinishedByOther() - 接口 中的方法org.apache.flink.runtime.jobmanager.OnCompletionActions
Job was finished by another JobMaster.
jobFinishedByOther() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by self.
JobGraph - org.apache.flink.runtime.jobgraph中的类
The JobGraph represents a Flink dataflow program, at the low level that the JobManager accepts.
JobGraph(String) - 类 的构造器org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, and a random job ID.
JobGraph(JobID, String) - 类 的构造器org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given job ID (or a random ID, if null is passed), the given name and the given execution configuration (see ExecutionConfig).
JobGraph(JobVertex...) - 类 的构造器org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with no name, a random job ID, the given ExecutionConfig, and the given job vertices.
JobGraph(String, JobVertex...) - 类 的构造器org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, a random job ID, and the given job vertices.
JobGraph(JobID, String, JobVertex...) - 类 的构造器org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, the given jobId or a random one if null supplied, and the given job vertices.
jobGraphFileName - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
JobGraphRetriever - org.apache.flink.runtime.entrypoint.component中的接口
Interface which allows to retrieve the JobGraph.
jobID - 类 中的变量org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
jobId() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
jobId(JobID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
jobID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
jobID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
jobID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
jobId - 类 中的变量org.apache.flink.runtime.metrics.groups.JobMetricGroup
The ID of the job represented by this metrics group.
jobId() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
jobID - 类 中的变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
 
JobIDDeserializer - org.apache.flink.runtime.rest.messages.json中的类
Json deserializer for JobID.
JobIDDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobIDDeserializer
 
jobIdfromPath(String) - 类 中的静态方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Returns the JobID from the given path in ZooKeeper.
jobIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
 
JobIDPathParameter - org.apache.flink.runtime.rest.messages中的类
Path parameter identifying jobs.
JobIDPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
JobIDSerializer - org.apache.flink.runtime.rest.messages.json中的类
Json serializer for JobID.
JobIDSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobIDSerializer
 
JobIdsHandler - org.apache.flink.runtime.rest.handler.job中的类
Handler for job IDs.
JobIdsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobIdsWithStatusOverview, EmptyMessageParameters>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobIdsHandler
 
JobIdsWithStatusesOverviewHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobIdsWithStatusOverview.
JobIdsWithStatusOverview - org.apache.flink.runtime.messages.webmonitor中的类
An overview of how many jobs are in which status.
JobIdsWithStatusOverview(Collection<JobIdsWithStatusOverview.JobIdWithStatus>) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
JobIdsWithStatusOverview(JobIdsWithStatusOverview, JobIdsWithStatusOverview) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
JobIdsWithStatusOverview.JobIdWithStatus - org.apache.flink.runtime.messages.webmonitor中的类
 
JobIdWithStatus(JobID, JobStatus) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
JobInformation - org.apache.flink.runtime.executiongraph中的类
Container class for job information which is stored in the ExecutionGraph.
JobInformation(JobID, String, SerializedValue<ExecutionConfig>, Configuration, Collection<PermanentBlobKey>, Collection<URL>) - 类 的构造器org.apache.flink.runtime.executiongraph.JobInformation
 
JobLeaderIdActions - org.apache.flink.runtime.resourcemanager中的接口
Interface for actions called by the JobLeaderIdService.
JobLeaderIdService - org.apache.flink.runtime.resourcemanager中的类
Service which retrieves for a registered job the current job leader id (the leader id of the job manager responsible for the job).
JobLeaderIdService(HighAvailabilityServices, ScheduledExecutor, Time) - 类 的构造器org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
JobLeaderListener - org.apache.flink.runtime.taskexecutor中的接口
Listener for the JobLeaderService.
jobLeaderLostLeadership(JobID, JobMasterId) - 接口 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Callback when a monitored job leader lost its leadership.
jobLeaderLostLeadership(JobID, JobMasterId) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
JobLeaderService - org.apache.flink.runtime.taskexecutor中的类
This service has the responsibility to monitor the job leaders (the job manager which is leader for a given job) for all registered jobs.
JobLeaderService(TaskManagerLocation, RetryingRegistrationConfiguration) - 类 的构造器org.apache.flink.runtime.taskexecutor.JobLeaderService
 
jobManager() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
jobManagerAddress() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
JobManagerCliOptions - org.apache.flink.runtime.jobmanager中的类
The command line parameters passed to the JobManager.
JobManagerCliOptions() - 类 的构造器org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
JobManagerConnection - org.apache.flink.runtime.taskexecutor中的类
Container class for JobManager specific communication utils used by the TaskExecutor.
JobManagerConnection(JobID, ResourceID, JobMasterGateway, TaskManagerActions, CheckpointResponder, GlobalAggregateManager, LibraryCacheManager, ResultPartitionConsumableNotifier, PartitionProducerStateChecker) - 类 的构造器org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
JobManagerException - org.apache.flink.runtime.jobmaster中的异常错误
Base exception thrown by the JobMaster.
JobManagerException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobManagerException
 
JobManagerException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobManagerException
 
JobManagerException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobManagerException
 
jobManagerGainedLeadership(JobID, JobMasterGateway, JMTMRegistrationSuccess) - 接口 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback if a job manager has gained leadership for the job identified by the job id and a connection could be established to this job manager.
JobManagerJobMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing everything belonging to a specific job, running on the JobManager.
JobManagerJobMetricGroup(MetricRegistry, JobManagerMetricGroup, JobID, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
JobManagerJobMetricGroupFactory - org.apache.flink.runtime.jobmaster.factories中的接口
Factory interface for JobManagerJobMetricGroup.
JobManagerJobScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the JobMetricGroup.
JobManagerJobScopeFormat(String, JobManagerScopeFormat) - 类 的构造器org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
 
jobManagerLostLeadership(JobID, JobMasterId) - 接口 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback if the job leader for the job with the given job id lost its leadership.
JobManagerMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing a JobManager.
JobManagerMetricGroup(MetricRegistry, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
JobManagerMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Handler that returns JobManager metrics.
JobManagerMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
 
JobManagerMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobManagerMetricsMessageParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobManagerMetricsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
 
JobManagerMode - org.apache.flink.runtime.jobmanager中的枚举
The startup mode for the JobManager.
JobManagerQueryScopeInfo() - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
JobManagerQueryScopeInfo(String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
JobManagerRegistration - org.apache.flink.runtime.resourcemanager.registration中的类
Container for JobManager related registration information, such as the leader id or the job id.
JobManagerRegistration(JobID, ResourceID, JobMasterGateway) - 类 的构造器org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
JobManagerRunner - org.apache.flink.runtime.jobmaster中的类
The runner for the job manager.
JobManagerRunner(JobGraph, JobMasterServiceFactory, HighAvailabilityServices, LibraryCacheManager, Executor, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.jobmaster.JobManagerRunner
Exceptions that occur while creating the JobManager or JobManagerRunner are directly thrown and not reported to the given FatalErrorHandler.
JobManagerRunnerFactory - org.apache.flink.runtime.dispatcher中的接口
Factory for a JobManagerRunner.
JobManagerScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the JobManagerMetricGroup.
JobManagerScopeFormat(String) - 类 的构造器org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
 
JobManagerSharedServices - org.apache.flink.runtime.jobmaster中的类
Utility class which holds all auxiliary shared services used by the JobMaster.
JobManagerSharedServices(ScheduledExecutorService, LibraryCacheManager, RestartStrategyFactory, StackTraceSampleCoordinator, BackPressureStatsTracker, BlobWriter) - 类 的构造器org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
JobManagerTable - org.apache.flink.runtime.taskexecutor中的类
Container for multiple JobManagerConnection registered under their respective job id.
JobManagerTable() - 类 的构造器org.apache.flink.runtime.taskexecutor.JobManagerTable
 
JobManagerTaskRestore - org.apache.flink.runtime.checkpoint中的类
This class encapsulates the data from the job manager to restore a task.
JobManagerTaskRestore(long, TaskStateSnapshot) - 类 的构造器org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
 
JobMaster - org.apache.flink.runtime.jobmaster中的类
JobMaster implementation.
JobMaster(RpcService, JobMasterConfiguration, ResourceID, JobGraph, HighAvailabilityServices, SlotPoolFactory, SchedulerFactory, JobManagerSharedServices, HeartbeatServices, JobManagerJobMetricGroupFactory, OnCompletionActions, FatalErrorHandler, ClassLoader) - 类 的构造器org.apache.flink.runtime.jobmaster.JobMaster
 
JobMasterConfiguration - org.apache.flink.runtime.jobmaster中的类
Configuration for the JobMaster.
JobMasterConfiguration(Time, Time, String, RetryingRegistrationConfiguration, Configuration) - 类 的构造器org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
JobMasterException - org.apache.flink.runtime.jobmaster.exceptions中的异常错误
Base class for all JobMaster related exceptions.
JobMasterException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException - org.apache.flink.runtime.jobmaster中的异常错误
Base class for JobMaster related exceptions.
JobMasterException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobMasterException
 
JobMasterException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobMasterException
 
JobMasterException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobMasterException
 
jobMasterFailed(Throwable) - 接口 中的方法org.apache.flink.runtime.jobmanager.OnCompletionActions
The JobMaster failed while executing the job.
jobMasterFailed(Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
JobMasterGateway - org.apache.flink.runtime.jobmaster中的接口
JobMaster rpc gateway interface.
JobMasterId - org.apache.flink.runtime.jobmaster中的类
The JobMaster fencing token.
JobMasterId(UUID) - 类 的构造器org.apache.flink.runtime.jobmaster.JobMasterId
Creates a JobMasterId that takes the bits from the given UUID.
JobMasterRegistrationSuccess - org.apache.flink.runtime.jobmaster中的类
Base class for responses from the ResourceManager to a registration attempt by a JobMaster.
JobMasterRegistrationSuccess(ResourceManagerId, ResourceID) - 类 的构造器org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
JobMasterService - org.apache.flink.runtime.jobmaster中的接口
Interface which specifies the JobMaster service.
JobMasterServiceFactory - org.apache.flink.runtime.jobmaster.factories中的接口
Factory for a JobMasterService.
JobMessageParameters - org.apache.flink.runtime.rest.messages中的类
Message parameters which require a job path parameter.
JobMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.JobMessageParameters
 
JobMetricGroup<C extends ComponentMetricGroup<C>> - org.apache.flink.runtime.metrics.groups中的类
Special abstract MetricGroup representing everything belonging to a specific job.
JobMetricGroup(MetricRegistry, C, JobID, String, String[]) - 类 的构造器org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
JobMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Request handler that returns for a given job a list of all available metrics or the values for a set of metrics.
JobMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
 
JobMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobMetricsMessageParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobMetricsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
 
JobModificationException - org.apache.flink.runtime.jobmaster.exceptions中的异常错误
Base class for all exception which originate from a failed job modification.
JobModificationException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
JobModificationException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
JobModificationException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
jobName - 类 中的变量org.apache.flink.runtime.metrics.groups.JobMetricGroup
The name of the job represented by this metrics group.
jobName() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
jobNotFinished(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
jobNotFinished(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
 
JobNotFinishedException - org.apache.flink.runtime.jobmaster中的异常错误
Exception indicating that a Flink job has not been finished.
JobNotFinishedException(JobID) - 异常错误 的构造器org.apache.flink.runtime.jobmaster.JobNotFinishedException
 
jobPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.JobMessageParameters
 
jobPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
JobPlanHandler - org.apache.flink.runtime.rest.handler.job中的类
Handler serving the job execution plan.
JobPlanHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobPlanInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobPlanHandler
 
JobPlanHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobPlanHandler.
JobPlanInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobPlanHandler.
JobPlanInfo(String) - 类 的构造器org.apache.flink.runtime.rest.messages.JobPlanInfo
 
JobPlanInfo(JobPlanInfo.RawJson) - 类 的构造器org.apache.flink.runtime.rest.messages.JobPlanInfo
 
JobPlanInfo.RawJson - org.apache.flink.runtime.rest.messages中的类
Simple wrapper around a raw JSON string.
JobPlanInfo.RawJson.Deserializer - org.apache.flink.runtime.rest.messages中的类
Json deserializer for the JobPlanInfo.RawJson.
JobPlanInfo.RawJson.Serializer - org.apache.flink.runtime.rest.messages中的类
Json serializer for the JobPlanInfo.RawJson.
JobQueryScopeInfo(String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
JobQueryScopeInfo(String, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
 
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - 接口 中的方法org.apache.flink.runtime.jobmanager.OnCompletionActions
Job reached a globally terminal state.
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by JobManager.
JobRestEndpointFactory - org.apache.flink.runtime.rest中的枚举
JobResult - org.apache.flink.runtime.jobmaster中的类
Similar to JobExecutionResult but with an optional SerializedThrowable when the job failed.
JobResult.Builder - org.apache.flink.runtime.jobmaster中的类
Builder for JobResult.
JobResultDeserializer - org.apache.flink.runtime.rest.messages.json中的类
JSON deserializer for JobResult.
JobResultDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobResultDeserializer
 
JobResultSerializer - org.apache.flink.runtime.rest.messages.json中的类
JSON serializer for JobResult.
JobResultSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobResultSerializer
 
JobRetrievalException - org.apache.flink.runtime.client中的异常错误
Exception used to indicate that a job couldn't be retrieved from the JobManager
JobRetrievalException(JobID, String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, String) - 异常错误 的构造器org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobRetrievalException
 
JobsFilterQueryParameter - org.apache.flink.runtime.rest.messages.job.metrics中的类
MessageQueryParameter for selecting jobs when aggregating metrics.
JobsOverview - org.apache.flink.runtime.messages.webmonitor中的类
An overview of how many jobs are in which status.
JobsOverview(int, int, int, int) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
JobsOverview(JobsOverview, JobsOverview) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
JobsOverviewHandler - org.apache.flink.runtime.rest.handler.job中的类
Overview handler for jobs.
JobsOverviewHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, MultipleJobsDetails, EmptyMessageParameters>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
 
JobsOverviewHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for JobsOverviewHandler.
JobStatus - org.apache.flink.runtime.jobgraph中的枚举
Possible states of a job once it has been accepted by the job manager.
jobStatusChanges(JobID, JobStatus, long, Throwable) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
jobStatusChanges(JobID, JobStatus, long, Throwable) - 接口 中的方法org.apache.flink.runtime.executiongraph.JobStatusListener
This method is called whenever the status of the job changes.
jobStatusChanges(JobID, JobStatus, long, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
JobStatusListener - org.apache.flink.runtime.executiongraph中的接口
Interface for observers that monitor the status of a job.
JobStatusMessage - org.apache.flink.runtime.client中的类
A simple message that holds the state of a job execution.
JobStatusMessage(JobID, String, JobStatus, long) - 类 的构造器org.apache.flink.runtime.client.JobStatusMessage
 
JobSubmissionException - org.apache.flink.runtime.client中的异常错误
This exception denotes an error while submitting a job to the JobManager.
JobSubmissionException(JobID, String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobSubmissionException
 
JobSubmissionException(JobID, String) - 异常错误 的构造器org.apache.flink.runtime.client.JobSubmissionException
 
JobSubmitHandler - org.apache.flink.runtime.rest.handler.job中的类
This handler can be used to submit jobs to a Flink cluster.
JobSubmitHandler(GatewayRetriever<? extends DispatcherGateway>, Time, Map<String, String>, Executor, Configuration) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobSubmitHandler
 
JobSubmitHeaders - org.apache.flink.runtime.rest.messages.job中的类
These headers define the protocol for submitting a job to a flink cluster.
JobSubmitRequestBody - org.apache.flink.runtime.rest.messages.job中的类
Request for submitting a job.
JobSubmitRequestBody(String, Collection<String>, Collection<JobSubmitRequestBody.DistributedCacheFile>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
JobSubmitRequestBody.DistributedCacheFile - org.apache.flink.runtime.rest.messages.job中的类
Descriptor for a distributed cache file.
JobSubmitResponseBody - org.apache.flink.runtime.rest.messages.job中的类
Response to the submission of a job, containing a URL from which the status of the job can be retrieved from.
JobSubmitResponseBody(String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
 
JobTerminationHandler - org.apache.flink.runtime.rest.handler.job中的类
Request handler for the cancel and stop request.
JobTerminationHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, JobTerminationMessageParameters>, TerminationModeQueryParameter.TerminationMode) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobTerminationHandler
 
JobTerminationHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobTerminationHandler.
JobTerminationMessageParameters - org.apache.flink.runtime.rest.messages中的类
Parameters for job related REST handlers.
JobTerminationMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
JobTimeoutException - org.apache.flink.runtime.client中的异常错误
An exception which is thrown by the JobClient if the job manager is no longer reachable.
JobTimeoutException(JobID, String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.client.JobTimeoutException
 
jobUrl - 类 中的变量org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
The URL under which the job status can monitored.
JobVertex - org.apache.flink.runtime.jobgraph中的类
The base class for job vertexes.
JobVertex(String) - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertex(String, JobVertexID) - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertexAccumulatorsHandler - org.apache.flink.runtime.rest.handler.job中的类
Request handler for the job vertex accumulators.
JobVertexAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
 
JobVertexAccumulatorsHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobVertexAccumulatorsHandler.
JobVertexAccumulatorsInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobVertexAccumulatorsHandler.
JobVertexAccumulatorsInfo(String, Collection<UserAccumulator>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
 
JobVertexBackPressureHandler - org.apache.flink.runtime.rest.handler.job中的类
Request handler for the job vertex back pressure.
JobVertexBackPressureHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexBackPressureInfo, JobVertexMessageParameters>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
 
JobVertexBackPressureHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobVertexBackPressureHandler.
JobVertexBackPressureHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
 
JobVertexBackPressureInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobVertexBackPressureHandler.
JobVertexBackPressureInfo(JobVertexBackPressureInfo.VertexBackPressureStatus, JobVertexBackPressureInfo.VertexBackPressureLevel, Long, List<JobVertexBackPressureInfo.SubtaskBackPressureInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
JobVertexBackPressureInfo.SubtaskBackPressureInfo - org.apache.flink.runtime.rest.messages中的类
Nested class to encapsulate the sub tasks back pressure.
JobVertexBackPressureInfo.VertexBackPressureLevel - org.apache.flink.runtime.rest.messages中的枚举
Level of vertex back-pressure.
JobVertexBackPressureInfo.VertexBackPressureStatus - org.apache.flink.runtime.rest.messages中的枚举
Status of vertex back-pressure.
JobVertexDetailsHandler - org.apache.flink.runtime.rest.handler.job中的类
Request handler for the job vertex details.
JobVertexDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexDetailsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
 
JobVertexDetailsHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobVertexDetailsHandler.
JobVertexDetailsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
JobVertexDetailsInfo(JobVertexID, String, int, ExecutionState, long, long, long, Map<ExecutionState, Integer>, IOMetricsInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
JobVertexDetailsInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobVertexDetailsHandler.
JobVertexDetailsInfo(JobVertexID, String, int, long, List<JobVertexDetailsInfo.VertexTaskDetail>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
JobVertexDetailsInfo.VertexTaskDetail - org.apache.flink.runtime.rest.messages中的类
Vertex task detail class.
JobVertexID - org.apache.flink.runtime.jobgraph中的类
A class for statistically unique job vertex IDs.
JobVertexID() - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexID(byte[]) - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexID(long, long) - 类 的构造器org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexIDDeserializer - org.apache.flink.runtime.rest.messages.json中的类
Jackson deserializer for JobVertexID.
JobVertexIDDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobVertexIDDeserializer
 
JobVertexIDKeyDeserializer - org.apache.flink.runtime.rest.messages.json中的类
Jackson deserializer for JobVertexID.
JobVertexIDKeyDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobVertexIDKeyDeserializer
 
JobVertexIDKeySerializer - org.apache.flink.runtime.rest.messages.json中的类
Jackson serializer for JobVertexID used as a key serializer.
JobVertexIDKeySerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
 
jobVertexIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
 
JobVertexIdPathParameter - org.apache.flink.runtime.rest.messages中的类
Path parameter specifying a JobVertexID.
JobVertexIdPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
jobVertexIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
 
JobVertexIDSerializer - org.apache.flink.runtime.rest.messages.json中的类
Jackson serializer for JobVertexID.
JobVertexIDSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
 
JobVertexMessageParameters - org.apache.flink.runtime.rest.messages中的类
Message parameters for job vertex REST handlers.
JobVertexMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
 
JobVertexMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
已过时。
This class is subsumed by SubtaskMetricsHandler and is only kept for backwards-compatibility.
JobVertexMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
已过时。
 
JobVertexMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobVertexMetricsMessageParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
JobVertexMetricsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
 
JobVertexTaskManagersHandler - org.apache.flink.runtime.rest.handler.job中的类
A request handler that provides the details of a job vertex, including id, name, and the runtime and metrics of all its subtasks aggregated by TaskManager.
JobVertexTaskManagersHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexTaskManagersInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
 
JobVertexTaskManagersHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the JobVertexTaskManagersHandler.
JobVertexTaskManagersInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the JobVertexTaskManagersHandler.
JobVertexTaskManagersInfo(JobVertexID, String, long, Collection<JobVertexTaskManagersInfo.TaskManagersInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
JobVertexTaskManagersInfo.TaskManagersInfo - org.apache.flink.runtime.rest.messages中的类
Detailed information about task managers.
JoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
The join driver implements the logic of a join operator at runtime.
JoinDriver() - 类 的构造器org.apache.flink.runtime.operators.JoinDriver
 
JoinTaskIterator<V1,V2,O> - org.apache.flink.runtime.operators.util中的接口
Interface of an iterator that performs the logic of a match task.
JoinWithSolutionSetFirstDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
JoinWithSolutionSetFirstDriver() - 类 的构造器org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
JoinWithSolutionSetSecondDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
 
JoinWithSolutionSetSecondDriver() - 类 的构造器org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
JsonArchivist - org.apache.flink.runtime.webmonitor.history中的接口
Interface for all classes that want to participate in the archiving of job-related json responses.
JsonFactory - org.apache.flink.runtime.rest.handler.legacy中的类
A holder for the singleton Jackson JSON factory.
JsonPlanGenerator - org.apache.flink.runtime.jobgraph.jsonplan中的类
 
JsonPlanGenerator() - 类 的构造器org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
JvmShutdownSafeguard - org.apache.flink.runtime.util中的类
A utility that guards against blocking shutdown hooks that block JVM shutdown.

K

KeepAliveWrite - org.apache.flink.runtime.rest.handler.util中的类
Utilities to write.
KeepAliveWrite() - 类 的构造器org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
 
keepBuildSidePartitions - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
If true, build side partitions are kept for multiple probe steps.
KerberosUtils - org.apache.flink.runtime.security中的类
Provides vendor-specific Kerberos AppConfigurationEntry instances.
KerberosUtils() - 类 的构造器org.apache.flink.runtime.security.KerberosUtils
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
The constant subtask attempt KEY.
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
KEY - 类 中的静态变量org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
keyContext - 类 中的变量org.apache.flink.runtime.state.heap.StateTable
The key context view on the backend.
Keyed<K> - org.apache.flink.runtime.state中的接口
Interface for objects that have a key attribute.
KeyedBackendSerializationProxy<K> - org.apache.flink.runtime.state中的类
Serialization proxy for all meta data in keyed state backends.
KeyedBackendSerializationProxy(ClassLoader) - 类 的构造器org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
KeyedBackendSerializationProxy(TypeSerializer<K>, List<StateMetaInfoSnapshot>, boolean) - 类 的构造器org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
keyedStateBackend - 类 中的变量org.apache.flink.runtime.state.DefaultKeyedStateStore
 
KeyedStateBackend<K> - org.apache.flink.runtime.state中的接口
A keyed state backend provides methods for managing keyed state.
KeyedStateBackend.KeySelectionListener<K> - org.apache.flink.runtime.state中的接口
Listener is given a callback when KeyedStateBackend.setCurrentKey(K) is called (key context changes).
KeyedStateCheckpointOutputStream - org.apache.flink.runtime.state中的类
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.
KeyedStateCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream, KeyGroupRange) - 类 的构造器org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
KeyedStateFactory - org.apache.flink.runtime.state中的接口
This factory produces concrete internal state objects.
KeyedStateFunction<K,S extends org.apache.flink.api.common.state.State> - org.apache.flink.runtime.state中的接口
A function to be applied to all keyed states.
KeyedStateHandle - org.apache.flink.runtime.state中的接口
Base for the handles of the checkpointed states in keyed streams.
KeyExtractorFunction<T> - org.apache.flink.runtime.state中的接口
Function to extract a key from a given object.
keyExtractorFunction - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
Function to extract the key from a given element.
keyGroupCompressionDecorator - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
Decorates the input and output streams to write key-groups compressed.
keyGroupCompressionDecorator - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
KeyGroupedInternalPriorityQueue<T> - org.apache.flink.runtime.state中的接口
This interface exists as (temporary) adapter between the new InternalPriorityQueue and the old way in which timers are written in a snapshot.
KeyGroupedIterator<E> - org.apache.flink.runtime.util中的接口
 
KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的类
This implementation of InternalPriorityQueue is internally partitioned into sub-queues per key-group and essentially works as a heap-of-heaps.
KeyGroupPartitionedPriorityQueue(KeyExtractorFunction<T>, PriorityComparator<T>, KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T, PQ>, KeyGroupRange, int) - 类 的构造器org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement> - org.apache.flink.runtime.state.heap中的接口
Factory that produces the sub-queues that represent the partitions of a KeyGroupPartitionedPriorityQueue.
KeyGroupPartitioner<T> - org.apache.flink.runtime.state中的类
Class that contains the base algorithm for partitioning data into key-groups.
KeyGroupPartitioner(T[], int, T[], KeyGroupRange, int, KeyExtractorFunction<T>, KeyGroupPartitioner.ElementWriterFunction<T>) - 类 的构造器org.apache.flink.runtime.state.KeyGroupPartitioner
Creates a new KeyGroupPartitioner.
KeyGroupPartitioner.ElementReaderFunction<T> - org.apache.flink.runtime.state中的接口
This functional interface defines how one element is read from a DataInputView.
KeyGroupPartitioner.ElementWriterFunction<T> - org.apache.flink.runtime.state中的接口
This functional interface defines how one element is written to a DataOutputView.
KeyGroupPartitioner.KeyGroupElementsConsumer<T> - org.apache.flink.runtime.state中的接口
Functional interface to consume elements from a key group.
keyGroupRange - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
Range of key-groups for which this backend is responsible.
keyGroupRange - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
keyGroupRange - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
The key-group range for the input data, covered in this partitioning.
KeyGroupRange - org.apache.flink.runtime.state中的类
This class defines a range of key-group indexes.
KeyGroupRange(int, int) - 类 的构造器org.apache.flink.runtime.state.KeyGroupRange
Defines the range [startKeyGroup, endKeyGroup]
KeyGroupRangeAssignment - org.apache.flink.runtime.state中的类
 
KeyGroupRangeOffsets - org.apache.flink.runtime.state中的类
This class combines a key-group range with offsets that correspond to the key-groups in the range.
KeyGroupRangeOffsets(KeyGroupRange, long[]) - 类 的构造器org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given key-group range.
KeyGroupRangeOffsets(int, int, long[]) - 类 的构造器org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given start key-group to end key-group.
KeyGroupRangeOffsets(int, int) - 类 的构造器org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given start key-group to end key-group.
KeyGroupRangeOffsets(KeyGroupRange) - 类 的构造器org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets for the given key-group range, where all offsets are initially zero.
keyGroupReader(int) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
 
keyGroupReader(int) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
keyGroupReader(int) - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotRestore
This method returns a StateSnapshotKeyGroupReader that can be used to restore the state on a per-key-group basis.
KeyGroupsList - org.apache.flink.runtime.state中的接口
This interface offers ordered random read access to multiple key group ids.
KeyGroupsStateHandle - org.apache.flink.runtime.state中的类
A handle to the partitioned stream operator state after it has been checkpointed.
KeyGroupsStateHandle(KeyGroupRangeOffsets, StreamStateHandle) - 类 的构造器org.apache.flink.runtime.state.KeyGroupsStateHandle
 
KeyGroupStatePartitionStreamProvider - org.apache.flink.runtime.state中的类
This class provides access to an input stream that contains state data for one key group and the key group id.
KeyGroupStatePartitionStreamProvider(IOException, int) - 类 的构造器org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
KeyGroupStatePartitionStreamProvider(InputStream, int) - 类 的构造器org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
keySelected(K) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener
Callback when key context is switched.
keySerializer - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapState
 
keySerializerProvider - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
StateSerializerProvider for our key serializer.
keySerializerProvider - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
keySetA() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
keySetB() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
keytabEntry(String, String) - 类 中的静态方法org.apache.flink.runtime.security.KerberosUtils
 
KeytabOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays cluster-level Kerberos credentials (i.e. keytab) into a container.
KeytabOverlay(File) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay(Path) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the KeytabOverlay.
Krb5ConfOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays a Kerberos configuration file into a container.
Krb5ConfOverlay(File) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay(Path) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the Krb5ConfOverlay.
KvStateClientProxy - org.apache.flink.runtime.query中的接口
An interface for the Queryable State Client Proxy running on each Task Manager in the cluster.
KvStateEntry<K,N,V> - org.apache.flink.runtime.query中的类
An entry holding the InternalKvState along with its KvStateInfo.
KvStateEntry(InternalKvState<K, N, V>) - 类 的构造器org.apache.flink.runtime.query.KvStateEntry
 
KvStateInfo<K,N,V> - org.apache.flink.runtime.query中的类
Metadata about a InternalKvState.
KvStateInfo(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - 类 的构造器org.apache.flink.runtime.query.KvStateInfo
 
KvStateLocation - org.apache.flink.runtime.query中的类
Location information for all key groups of a InternalKvState instance.
KvStateLocation(JobID, JobVertexID, int, String) - 类 的构造器org.apache.flink.runtime.query.KvStateLocation
Creates the location information.
KvStateLocationOracle - org.apache.flink.runtime.jobmaster中的接口
Oracle for KvStateLocation in the cluster.
KvStateLocationRegistry - org.apache.flink.runtime.query中的类
Simple registry, which maps InternalKvState registration notifications to KvStateLocation instances.
KvStateLocationRegistry(JobID, Map<JobVertexID, ExecutionJobVertex>) - 类 的构造器org.apache.flink.runtime.query.KvStateLocationRegistry
Creates the registry for the job.
KvStateMessage - org.apache.flink.runtime.query中的接口
Actor messages for InternalKvState lookup and registration.
KvStateMessage.LookupKvStateLocation - org.apache.flink.runtime.query中的类
Actor message for looking up KvStateLocation.
KvStateMessage.NotifyKvStateRegistered - org.apache.flink.runtime.query中的类
Actor message for notification of KvState registration.
KvStateMessage.NotifyKvStateUnregistered - org.apache.flink.runtime.query中的类
Actor message for notification of KvState unregistration.
KvStateRegistry - org.apache.flink.runtime.query中的类
A registry for InternalKvState instances per task manager.
KvStateRegistry() - 类 的构造器org.apache.flink.runtime.query.KvStateRegistry
 
kvStateRegistry - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
KvStateRegistry helper for this task.
kvStateRegistry - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
KvStateRegistryGateway - org.apache.flink.runtime.jobmaster中的接口
Gateway to report key-value state registration and deregistrations.
KvStateRegistryListener - org.apache.flink.runtime.query中的接口
A listener for a KvStateRegistry.
KvStateServer - org.apache.flink.runtime.query中的接口
An interface for the Queryable State Server running on each Task Manager in the cluster.

L

LargeRecordHandler<T> - org.apache.flink.runtime.operators.sort中的类
 
LargeRecordHandler(TypeSerializer<T>, TypeComparator<T>, IOManager, MemoryManager, List<MemorySegment>, AbstractInvokable, int) - 类 的构造器org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
LatestCheckpoints(CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.FailedCheckpointStatistics, CheckpointingStatistics.RestoredCheckpointStatistics) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
lazyDestroy() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Destroys this buffer pool.
leaderAddress() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderAddress() - 类 中的方法org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderAddressAndId - org.apache.flink.runtime.leaderelection中的类
A combination of a leader address and leader id.
LeaderAddressAndId(String, UUID) - 类 的构造器org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderConnectingAddressListener() - 类 的构造器org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
LeaderConnectionInfo - org.apache.flink.runtime.util中的类
Wrapper class for a pair of connection address and leader session ID.
LeaderConnectionInfo(String, UUID) - 类 的构造器org.apache.flink.runtime.util.LeaderConnectionInfo
 
LeaderConnectionInfoListener() - 类 的构造器org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
LeaderContender - org.apache.flink.runtime.leaderelection中的接口
Interface which has to be implemented to take part in the leader election process of the LeaderElectionService.
LeaderElectionService - org.apache.flink.runtime.leaderelection中的接口
Interface for a service which allows to elect a leader among a group of contenders.
LeaderGatewayListener(ActorSystem, FiniteDuration) - 类 的构造器org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
LeaderGatewayRetriever<T extends RpcGateway> - org.apache.flink.runtime.webmonitor.retriever中的类
Retrieves and stores the leading RpcGateway.
LeaderGatewayRetriever() - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
 
leaderId() - 类 中的方法org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderIdMismatchException - org.apache.flink.runtime.highavailability中的异常错误
An exception thrown when the leader session id attached to a message does not match the leader session id that the receiver expects.
LeaderIdMismatchException(UUID, UUID) - 异常错误 的构造器org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
LeaderRetrievalException - org.apache.flink.runtime.leaderretrieval中的异常错误
This exception is thrown by the LeaderRetrievalUtils when the method retrieveLeaderGateway fails to retrieve the current leader's gateway.
LeaderRetrievalException(String) - 异常错误 的构造器org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalHandler<T extends RestfulGateway> - org.apache.flink.runtime.rest.handler中的类
SimpleChannelInboundHandler which encapsulates the leader retrieval logic for the REST endpoints.
LeaderRetrievalHandler(GatewayRetriever<? extends T>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
LeaderRetrievalListener - org.apache.flink.runtime.leaderretrieval中的接口
Classes which want to be notified about a changing leader by the LeaderRetrievalService have to implement this interface.
LeaderRetrievalService - org.apache.flink.runtime.leaderretrieval中的接口
This interface has to be implemented by a service which retrieves the current leader and notifies a listener about it.
LeaderRetrievalUtils - org.apache.flink.runtime.util中的类
Utility class to work with LeaderRetrievalService class.
LeaderRetrievalUtils.LeaderConnectionInfoListener - org.apache.flink.runtime.util中的类
Helper class which is used by the retrieveLeaderConnectionInfo method to retrieve the leader's akka URL and the current leader session ID.
LeaderRetrievalUtils.LeaderGatewayListener - org.apache.flink.runtime.util中的类
Helper class which is used by the retrieveLeaderGateway method as the LeaderRetrievalListener.
leaderRetriever - 类 中的变量org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
LeaderRetriever - org.apache.flink.runtime.webmonitor.retriever中的类
Retrieves and stores the current leader address.
LeaderRetriever() - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
leaderRetriever - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
leaderSessionId() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderSessionID() - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Returns the leaderSessionID associated with the remote actor or null.
leaderSessionID() - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
 
LeaderSessionMessageDecorator - org.apache.flink.runtime.messages中的类
Message decorator which wraps message which implement RequiresLeaderSessionID into a JobManagerMessages.LeaderSessionMessage.
LeaderSessionMessageDecorator(UUID) - 类 的构造器org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
Sets the leader session ID with which the messages will be decorated.
LeftOuterJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
The left outer join driver implements the logic of an outer join operator at runtime.
LeftOuterJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.LeftOuterJoinDriver
 
leftOverElement - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
LegacyStateMetaInfoReaders - org.apache.flink.runtime.state.metainfo中的类
This class holds the deprecated implementations of readers for state meta infos.
LegacyStateMetaInfoReaders.OperatorBackendStateMetaInfoReaderV1 - org.apache.flink.runtime.state.metainfo中的类
Reader for older versions of operator state (version 1)
LibraryCacheManager - org.apache.flink.runtime.execution.librarycache中的接口
 
LifoSetQueue<E> - org.apache.flink.runtime.jobmanager.scheduler中的类
A queue that returns elements in LIFO order and simultaneously maintains set characteristics, i.e., elements that are already in the queue may not be added another time.
LifoSetQueue() - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
ListeningBehaviour - org.apache.flink.runtime.akka中的枚举
Defines the listening behaviour of the JobClientActor and thus the messages which are sent from the JobManger to the JobClientActor.
listJobs(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
listJobs(Time) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherGateway
List the current set of submitted jobs.
listJobs() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
ListMemorySegmentSource - org.apache.flink.runtime.memory中的类
Simple memory segment source that draws segments from a list.
ListMemorySegmentSource(List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.memory.ListMemorySegmentSource
 
listResolvedRootSlotInfo(AbstractID) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
ListStateSnapshotTransformer(StateSnapshotTransformer<T>) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformer
 
ListStateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<T>) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformFactory
 
listStatus() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
List the statuses of the files/directories in the snapshot directory.
loadAndValidateCheckpoint(JobID, Map<JobVertexID, ExecutionJobVertex>, CompletedCheckpointStorageLocation, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
loadBigData(PermanentBlobService) - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Loads externalized data from the BLOB store back to the object.
loadCheckpointMetadata(DataInputStream, ClassLoader) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
loadConfiguration(EntrypointClusterConfiguration) - 类 中的静态方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
loadFailoverStrategy(Configuration, Logger) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Loads a FailoverStrategy Factory from the given configuration.
loadStateBackend(Configuration, ClassLoader, Logger) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
loadStateBackendFromConfig(Configuration, ClassLoader, Logger) - 类 中的静态方法org.apache.flink.runtime.state.StateBackendLoader
Loads the state backend from the configuration, from the parameter 'state.backend', as defined in CheckpointingOptions.STATE_BACKEND.
loadWebSubmissionExtension(GatewayRetriever<? extends DispatcherGateway>, Time, Map<String, String>, CompletableFuture<String>, Path, Executor, Configuration) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
Loads the WebMonitorExtension which enables web submission.
LOCAL_STATE_SUB_DIRECTORY_ROOT - 类 中的静态变量org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
LocalConnectionManager - org.apache.flink.runtime.io.network中的类
A connection manager implementation to bypass setup overhead for task managers running in local execution mode.
LocalConnectionManager() - 类 的构造器org.apache.flink.runtime.io.network.LocalConnectionManager
 
LocalFencedMessage<F extends Serializable,P> - org.apache.flink.runtime.rpc.messages中的类
Local FencedMessage implementation.
LocalFencedMessage(F, P) - 类 的构造器org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
LocalInputChannel - org.apache.flink.runtime.io.network.partition.consumer中的类
An input channel, which requests a local subpartition.
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, TaskIOMetricGroup) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, int, int, TaskIOMetricGroup) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
Locality - org.apache.flink.runtime.jobmanager.scheduler中的枚举
 
LocalRecoveryConfig - org.apache.flink.runtime.state中的类
This class encapsulates the completed configuration for local recovery, i.e. the root directories into which all file-based snapshots can be written and the general mode for the local recover feature.
LocalRecoveryConfig(boolean, LocalRecoveryDirectoryProvider) - 类 的构造器org.apache.flink.runtime.state.LocalRecoveryConfig
 
LocalRecoveryDirectoryProvider - org.apache.flink.runtime.state中的接口
Provides directories for local recovery.
LocalRecoveryDirectoryProviderImpl - org.apache.flink.runtime.state中的类
LocalRecoveryDirectoryProviderImpl(File, JobID, JobVertexID, int) - 类 的构造器org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
LocalRecoveryDirectoryProviderImpl(File[], JobID, JobVertexID, int) - 类 的构造器org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
LocalRpcInvocation - org.apache.flink.runtime.rpc.messages中的类
Local rpc invocation message containing the remote procedure name, its parameter types and the corresponding call arguments.
LocalRpcInvocation(String, Class<?>[], Object[]) - 类 的构造器org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
localStateStoreForSubtask(JobID, AllocationID, JobVertexID, int) - 类 中的方法org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
localStrategies - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The local strategies that are applied on the inputs.
LocalStrategy - org.apache.flink.runtime.operators.util中的枚举
Enumeration of all available local processing strategies tasks.
LocalTransportException - org.apache.flink.runtime.io.network.netty.exception中的异常错误
 
LocalTransportException(String, SocketAddress) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
 
LocalTransportException(String, SocketAddress, Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
 
LocationPreferenceConstraint - org.apache.flink.runtime.jobmanager.scheduler中的枚举
Defines the location preference constraint.
LocationPreferenceSlotSelectionStrategy - org.apache.flink.runtime.jobmaster.slotpool中的枚举
This class implements a SlotSelectionStrategy that is based on location preference hints.
lock - 类 中的变量org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
lockLocation() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Locks the location of this slot.
lockLocation(TaskManagerLocation) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Locks the location of this slot.
LOG - 类 中的静态变量org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
LOG - 类 中的变量org.apache.flink.runtime.akka.FlinkUntypedActor
 
log - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
The log object used for debugging.
LOG - 接口 中的静态变量org.apache.flink.runtime.blob.BlobWriter
 
LOG - 类 中的静态变量org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
log - 类 中的变量org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
LOG - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
Logger object for channel and its subclasses
LOG - 类 中的静态变量org.apache.flink.runtime.io.disk.iomanager.IOManager
Logging
log - 类 中的变量org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
LOG - 类 中的静态变量org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.BatchTask
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.JoinDriver
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
LOG - 类 中的静态变量org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
log - 类 中的变量org.apache.flink.runtime.registration.RegisteredRpcConnection
The logger for all log messages of this class.
log - 类 中的变量org.apache.flink.runtime.rest.handler.AbstractHandler
 
log - 类 中的变量org.apache.flink.runtime.rest.RestServerEndpoint
 
log - 类 中的变量org.apache.flink.runtime.rpc.RpcEndpoint
 
LOG - 类 中的静态变量org.apache.flink.runtime.security.DynamicConfiguration
 
LOG - 接口 中的静态变量org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
log - 类 中的变量org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
logAndThrowException(Exception, AbstractInvokable) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Prints an error message and throws the given exception.
logAsyncCompleted(Object, long) - 类 中的方法org.apache.flink.runtime.state.AbstractSnapshotStrategy
Logs the duration of the asynchronous snapshot part from the given start time.
logAsyncSnapshotComplete(long) - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
This method is invoked after completion of the snapshot and can be overridden to output a logging about the duration of the async part.
logEnvironmentInfo(Logger, String, String[]) - 类 中的静态方法org.apache.flink.runtime.util.EnvironmentInformation
Logs information about the environment, like code revision, current user, Java version, and JVM parameters.
logFile - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
LogFileHandlerSpecification - org.apache.flink.runtime.rest.handler.legacy.files中的类
Rest handler specification for the log file of the main cluster component.
logger - 类 中的变量org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
LogicalSlot - org.apache.flink.runtime.jobmaster中的接口
A logical slot represents a resource on a TaskManager into which a single task can be deployed.
LogicalSlot.Payload - org.apache.flink.runtime.jobmaster中的接口
Payload for a logical slot.
logSyncCompleted(Object, long) - 类 中的方法org.apache.flink.runtime.state.AbstractSnapshotStrategy
Logs the duration of the synchronous snapshot part from the given start time.
LongArrayList - org.apache.flink.runtime.util中的类
Minimal implementation of an array-backed list of longs
LongArrayList(int) - 类 的构造器org.apache.flink.runtime.util.LongArrayList
 
LookupKvStateLocation(JobID, String) - 类 的构造器org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Requests a KvStateLocation for the specified JobID and InternalKvState registration name.

M

main(String[]) - 类 中的静态方法org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
 
main(String[]) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
main(String[]) - 类 中的静态方法org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
 
MainThreadExecutable - org.apache.flink.runtime.rpc中的接口
Interface to execute Runnable and Callable in the main thread of the underlying RPC endpoint.
MainThreadValidatorUtil - org.apache.flink.runtime.rpc中的类
This utility exists to bridge between the visibility of the currentMainThread field in the RpcEndpoint.
MainThreadValidatorUtil(RpcEndpoint) - 类 的构造器org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
ManagedInitializationContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which operators can initialize by registering to managed state (i.e. state that is managed by state backends).
ManagedSnapshotContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which operators that use managed state (i.e. state that is managed by state backends) can perform a snapshot.
map(Tuple2<Integer, T>) - 类 中的方法org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
MapDriver<IT,OT> - org.apache.flink.runtime.operators中的类
Map task which is executed by a Task Manager.
MapDriver() - 类 的构造器org.apache.flink.runtime.operators.MapDriver
 
mapPartition(Iterable<IN>, Collector<Tuple2<Integer, IN>>) - 类 中的方法org.apache.flink.runtime.operators.udf.AssignRangeIndex
 
mapPartition(Iterable<T>, Collector<Object[][]>) - 类 中的方法org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
 
MapPartitionDriver<IT,OT> - org.apache.flink.runtime.operators中的类
MapPartition task which is executed by a Task Manager.
MapPartitionDriver() - 类 的构造器org.apache.flink.runtime.operators.MapPartitionDriver
 
MAPPER - 类 中的静态变量org.apache.flink.runtime.rest.handler.AbstractHandler
 
MapStateSnapshotTransformer(StateSnapshotTransformer<V>) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformer
 
MapStateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<V>) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformFactory
 
mark(int) - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
mark(int) - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
markActive() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark this slot as active.
markDataProduced() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
markDead() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
markFree() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as free.
markInactive() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as inactive/allocated.
markReleasing() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark this slot as releasing.
markSlotActive(AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as active.
markSlotInactive(AllocationID, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as inactive.
markSupported() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
markSupported() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
markUsed() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
MasterHooks - org.apache.flink.runtime.checkpoint.hooks中的类
Collection of methods to deal with checkpoint master hooks.
MasterState - org.apache.flink.runtime.checkpoint中的类
Simple encapsulation of state generated by checkpoint coordinator.
MasterState(String, byte[], int) - 类 的构造器org.apache.flink.runtime.checkpoint.MasterState
 
MasterTriggerRestoreHook<T> - org.apache.flink.runtime.checkpoint中的接口
The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint.
MasterTriggerRestoreHook.Factory - org.apache.flink.runtime.checkpoint中的接口
A factory to instantiate a MasterTriggerRestoreHook.
MaterializationExpiredException - org.apache.flink.runtime.broadcast中的异常错误
Indicates that the BroadcastVariableMaterialization has materialized the broadcast variable at some point but discarded it already.
MaterializationExpiredException() - 异常错误 的构造器org.apache.flink.runtime.broadcast.MaterializationExpiredException
 
materializeBroadcastVariable(String, int, BatchTask<?, ?>, MutableReader<?>, TypeSerializerFactory<T>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
Materializes the broadcast variable for the given name, scoped to the given task and its iteration superstep.
materializeVariable(MutableReader<?>, TypeSerializerFactory<?>, BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
max - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
MAX_FILE_STATE_THRESHOLD - 类 中的静态变量org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
Maximum size of state that is stored with the metadata, rather than in files.
MAX_NUM_WRITE_BUFFERS - 类 中的静态变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The maximal number of buffers to use by the writers.
maxFanIn - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MaybeOffloaded() - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.MaybeOffloaded
 
mean - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
median - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
MemCheckpointStreamFactory - org.apache.flink.runtime.state.memory中的类
CheckpointStreamFactory that produces streams that write to in-memory byte arrays.
MemCheckpointStreamFactory(int) - 类 的构造器org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
Creates a new in-memory stream factory that accepts states whose serialized forms are up to the given number of bytes.
MemCheckpointStreamFactory.MemoryCheckpointOutputStream - org.apache.flink.runtime.state.memory中的类
A CheckpointStateOutputStream that writes into a byte array.
memManager - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MEMORY_COMMITTED - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
MEMORY_MAX - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
MEMORY_STATE_BACKEND_NAME - 类 中的静态变量org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the MemoryState backend that checkpoints to the JobManager
MEMORY_USED - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
memoryAddress() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
MemoryAllocationException - org.apache.flink.runtime.memory中的异常错误
An exception to be thrown when a memory allocation operation is not successful.
MemoryAllocationException() - 异常错误 的构造器org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(String) - 异常错误 的构造器org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryArchivedExecutionGraphStore - org.apache.flink.runtime.dispatcher中的类
ArchivedExecutionGraphStore implementation which stores the ArchivedExecutionGraph in memory.
MemoryArchivedExecutionGraphStore() - 类 的构造器org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
MemoryBackendCheckpointStorage - org.apache.flink.runtime.state.memory中的类
An implementation of a checkpoint storage for the MemoryStateBackend.
MemoryBackendCheckpointStorage(JobID, Path, Path, int) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
Creates a new MemoryBackendCheckpointStorage.
MemoryBlockIterator - org.apache.flink.runtime.util中的接口
The memory block iterator is an iterator that always buffers a block of elements in memory.
MemoryCheckpointOutputStream(int) - 类 的构造器org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
MemoryLogger - org.apache.flink.runtime.taskmanager中的类
A thread the periodically logs statistics about: Heap and non-heap memory usage Memory pools and pool usage Garbage collection times and counts
MemoryLogger(Logger, long, ActorSystem) - 类 的构造器org.apache.flink.runtime.taskmanager.MemoryLogger
Creates a new memory logger that logs in the given interval and lives as long as the given actor system.
MemoryManager - org.apache.flink.runtime.memory中的类
The memory manager governs the memory that Flink uses for sorting, hashing, and caching.
MemoryManager(long, int) - 类 的构造器org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity, using the default page size.
MemoryManager(long, int, int, MemoryType, boolean) - 类 的构造器org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity and given page size.
memoryManager - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
memoryManager - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
memoryManager - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory manager through which memory is allocated and released.
MemoryStateBackend - org.apache.flink.runtime.state.memory中的类
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
MemoryStateBackend() - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(boolean) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(int) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes.
MemoryStateBackend(int, boolean) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes and that uses asynchronous snashots as configured.
MemoryStateBackend(String, String) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new MemoryStateBackend, setting optionally the path to persist checkpoint metadata to, and to persist savepoints to.
MemoryStateBackend(String, String, int, TernaryBoolean) - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new MemoryStateBackend, setting optionally the paths to persist checkpoint metadata and savepoints to, as well as configuring state thresholds and asynchronous operations.
MemoryStateBackendFactory - org.apache.flink.runtime.state.memory中的类
A factory that creates an MemoryStateBackend from a configuration.
MemoryStateBackendFactory() - 类 的构造器org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
 
mergeChannelList(List<UnilateralSortMerger.ChannelWithBlockCount>, List<MemorySegment>, List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the given sorted runs to a smaller number of sorted runs.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeInto(CoLocationGroup) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
MergeIterator<E> - org.apache.flink.runtime.operators.sort中的类
An iterator that returns a sorted merge of the sequences of elements from a set of iterators, assuming those sequences are ordered themselves.
MergeIterator(List<MutableObjectIterator<E>>, TypeComparator<E>) - 类 的构造器org.apache.flink.runtime.operators.sort.MergeIterator
 
mergeNamespaces(N, Collection<N>) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalMergingState
Merges the state of the current key for the given source namespaces into the state of the target namespace.
mergeReadMemory - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
message() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
 
message() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
message() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
message() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the optional message with details, for logging and debugging.
message() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.StopCluster
 
MessageDecorator - org.apache.flink.runtime.messages中的接口
Interface for message decorators
MessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - org.apache.flink.runtime.rest.messages中的接口
This class links RequestBodys to ResponseBodys types and contains meta-data required for their http headers.
MessageParameter<X> - org.apache.flink.runtime.rest.messages中的类
This class represents a single path/query parameter that can be used for a request.
MessageParameter(String, MessageParameter.MessageParameterRequisiteness) - 类 的构造器org.apache.flink.runtime.rest.messages.MessageParameter
 
MessageParameter.MessageParameterRequisiteness - org.apache.flink.runtime.rest.messages中的枚举
Enum for indicating whether a parameter is mandatory or optional.
MessageParameters - org.apache.flink.runtime.rest.messages中的类
This class defines the path/query MessageParameters that can be used for a request.
MessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.MessageParameters
 
MessagePathParameter<X> - org.apache.flink.runtime.rest.messages中的类
This class represents path parameters of a request.
MessagePathParameter(String) - 类 的构造器org.apache.flink.runtime.rest.messages.MessagePathParameter
 
MessageQueryParameter<X> - org.apache.flink.runtime.rest.messages中的类
This class represents query parameters of a request.
MessageQueryParameter(String, MessageParameter.MessageParameterRequisiteness) - 类 的构造器org.apache.flink.runtime.rest.messages.MessageQueryParameter
 
METADATA_FILE_NAME - 类 中的静态变量org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The name of the metadata files in checkpoints / savepoints.
metaInfo - 类 中的变量org.apache.flink.runtime.state.heap.StateTable
Combined meta information such as name and serializers for this state.
meter(int, M) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
meter(String, M) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
meter(String, M) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
meter(int, M) - 类 中的方法org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
MeterDump(QueryScopeInfo, String, double) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
MethodVisitorImpl(int) - 类 的构造器org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
Metric - org.apache.flink.runtime.rest.messages.job.metrics中的类
Response type for a Metric and Metric-Value-Pair.
Metric(String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.Metric
Creates a new Metric with a possible value.
Metric(String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.Metric
Creates a new Metric without a value.
METRIC_CATEGORY_COUNTER - 类 中的静态变量org.apache.flink.runtime.metrics.dump.MetricDump
Categories to be returned by MetricDump.getCategory() to avoid instanceof checks.
METRIC_CATEGORY_GAUGE - 类 中的静态变量org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_CATEGORY_HISTOGRAM - 类 中的静态变量org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_CATEGORY_METER - 类 中的静态变量org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
METRIC_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
METRIC_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
METRIC_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
METRIC_QUERY_SERVICE_NAME - 类 中的静态变量org.apache.flink.runtime.metrics.dump.MetricQueryService
 
MetricCollectionResponseBody - org.apache.flink.runtime.rest.messages.job.metrics中的类
Response type for a collection of metrics.
MetricCollectionResponseBody(Collection<Metric>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
 
MetricCollectionResponseBody.Deserializer - org.apache.flink.runtime.rest.messages.job.metrics中的类
JSON deserializer for MetricCollectionResponseBody.
MetricCollectionResponseBody.Serializer - org.apache.flink.runtime.rest.messages.job.metrics中的类
JSON serializer for MetricCollectionResponseBody.
MetricDump - org.apache.flink.runtime.metrics.dump中的类
A container for a dumped metric that contains the scope, name and value(s) of the metric.
MetricDump.CounterDump - org.apache.flink.runtime.metrics.dump中的类
Container for the value of a Counter.
MetricDump.GaugeDump - org.apache.flink.runtime.metrics.dump中的类
Container for the value of a Gauge as a string.
MetricDump.HistogramDump - org.apache.flink.runtime.metrics.dump中的类
Container for the values of a Histogram.
MetricDump.MeterDump - org.apache.flink.runtime.metrics.dump中的类
Container for the rate of a Meter.
MetricDumpDeserializer() - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
 
MetricDumpSerialization - org.apache.flink.runtime.metrics.dump中的类
Utility class for the serialization of metrics.
MetricDumpSerialization.MetricDumpDeserializer - org.apache.flink.runtime.metrics.dump中的类
Deserializer for reading a list of MetricDumps from a MetricDumpSerialization.MetricSerializationResult.
MetricDumpSerialization.MetricDumpSerializer - org.apache.flink.runtime.metrics.dump中的类
Serializes a set of metrics into a MetricDumpSerialization.MetricSerializationResult.
MetricDumpSerialization.MetricSerializationResult - org.apache.flink.runtime.metrics.dump中的类
This class encapsulates all serialized metrics and a count for each metric type.
MetricDumpSerializer() - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
 
MetricFetcher - org.apache.flink.runtime.rest.handler.legacy.metrics中的接口
The MetricFetcher can be used to fetch metrics from the JobManager and all registered TaskManagers.
MetricFetcherImpl<T extends RestfulGateway> - org.apache.flink.runtime.rest.handler.legacy.metrics中的类
Implementation of MetricFetcher which fetches metrics from the MetricQueryServiceGateway.
MetricFetcherImpl(GatewayRetriever<T>, MetricQueryServiceRetriever, Executor, Time, long) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
 
MetricNames - org.apache.flink.runtime.metrics中的类
Collection of metric names.
MetricQueryService - org.apache.flink.runtime.metrics.dump中的类
The MetricQueryService creates a key-value representation of all metrics currently registered with Flink when queried.
MetricQueryService(long) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricQueryService
 
MetricQueryServiceGateway - org.apache.flink.runtime.webmonitor.retriever中的接口
Gateway to communicate with a QueryService.
MetricQueryServiceRetriever - org.apache.flink.runtime.webmonitor.retriever中的接口
MetricRegistry - org.apache.flink.runtime.metrics中的接口
Interface for a metric registry.
MetricRegistryConfiguration - org.apache.flink.runtime.metrics中的类
Configuration object for MetricRegistryImpl.
MetricRegistryConfiguration(ScopeFormats, char, List<Tuple2<String, Configuration>>, long) - 类 的构造器org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
MetricRegistryImpl - org.apache.flink.runtime.metrics中的类
A MetricRegistry keeps track of all registered Metrics.
MetricRegistryImpl(MetricRegistryConfiguration) - 类 的构造器org.apache.flink.runtime.metrics.MetricRegistryImpl
Creates a new MetricRegistry and starts the configured reporter.
metrics - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
metrics - 类 中的变量org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
 
MetricsAggregationParameter - org.apache.flink.runtime.rest.messages.job.metrics中的类
TODO: add javadoc.
MetricsAggregationParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
 
MetricsAggregationParameter.AggregationMode - org.apache.flink.runtime.rest.messages.job.metrics中的枚举
The available aggregations.
MetricSerializationResult(byte[], byte[], byte[], byte[], int, int, int, int) - 类 的构造器org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
metricsFilterParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
 
metricsFilterParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
 
MetricsFilterParameter - org.apache.flink.runtime.rest.messages.job.metrics中的类
MessageQueryParameter for filtering metrics provided by MetricStore.
MetricsFilterParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
 
metricsFilterParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
 
MetricStore - org.apache.flink.runtime.rest.handler.legacy.metrics中的类
Nested data-structure to store metrics.
MetricStore() - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
MetricStore.ComponentMetricStore - org.apache.flink.runtime.rest.handler.legacy.metrics中的类
Structure containing metrics of a single component.
MetricStore.TaskManagerMetricStore - org.apache.flink.runtime.rest.handler.legacy.metrics中的类
Sub-structure containing metrics of a single TaskManager.
MetricStore.TaskMetricStore - org.apache.flink.runtime.rest.handler.legacy.metrics中的类
Sub-structure containing metrics of a single Task.
MetricUtils - org.apache.flink.runtime.metrics.util中的类
Utility class to register pre-defined metric sets.
MimeTypes - org.apache.flink.runtime.rest.handler.util中的类
Simple utility class that resolves file extensions to MIME types.
min - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
MIN_NUM_SORT_MEM_SEGMENTS - 类 中的静态变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimum number of segments that are required for the sort to operate.
MIN_NUM_WRITE_BUFFERS - 类 中的静态变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimal number of buffers to use by the writers.
MIN_PAGE_SIZE - 类 中的静态变量org.apache.flink.runtime.memory.MemoryManager
The minimal memory page size.
MiniCluster - org.apache.flink.runtime.minicluster中的类
MiniCluster to execute Flink jobs locally.
MiniCluster(MiniClusterConfiguration) - 类 的构造器org.apache.flink.runtime.minicluster.MiniCluster
Creates a new Flink mini cluster based on the given configuration.
MiniCluster.CommonRpcServiceFactory - org.apache.flink.runtime.minicluster中的类
Factory which returns always the common RpcService.
MiniCluster.DedicatedRpcServiceFactory - org.apache.flink.runtime.minicluster中的类
Factory which creates and registers new RpcService.
MiniCluster.RpcServiceFactory - org.apache.flink.runtime.minicluster中的接口
Internal factory for RpcService.
MiniClusterConfiguration - org.apache.flink.runtime.minicluster中的类
Configuration object for the MiniCluster.
MiniClusterConfiguration(Configuration, int, RpcServiceSharing, String) - 类 的构造器org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
MiniClusterConfiguration.Builder - org.apache.flink.runtime.minicluster中的类
Builder for the MiniClusterConfiguration.
MiniDispatcher - org.apache.flink.runtime.dispatcher中的类
Mini Dispatcher which is instantiated as the dispatcher component by the JobClusterEntrypoint.
MiniDispatcher(RpcService, String, Configuration, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, JobManagerRunnerFactory, FatalErrorHandler, HistoryServerArchivist, JobGraph, ClusterEntrypoint.ExecutionMode) - 类 的构造器org.apache.flink.runtime.dispatcher.MiniDispatcher
 
MiniDispatcherRestEndpoint - org.apache.flink.runtime.jobmaster中的类
REST endpoint for the JobClusterEntrypoint.
MiniDispatcherRestEndpoint(RestServerEndpointConfiguration, GatewayRetriever<? extends RestfulGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.jobmaster.MiniDispatcherRestEndpoint
 
MinMaxAvgStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Minimum, maximum and average statistics.
MinMaxAvgStatistics(long, long, long) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
MinMaxAvgStats - org.apache.flink.runtime.checkpoint中的类
Helper for keeping track of min/max/average summaries.
mkdirs() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
monitorTarget(ResourceID, HeartbeatTarget<O>) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManager
Start monitoring a HeartbeatTarget.
monitorTarget(ResourceID, HeartbeatTarget<O>) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
moreAvailable() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
moveElementToIdx(T, int) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
MultipleJobsDetails - org.apache.flink.runtime.messages.webmonitor中的类
An actor messages describing details of various jobs.
MultipleJobsDetails(Collection<JobDetails>) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
MutableHashTable<BT,PT> - org.apache.flink.runtime.operators.hash中的类
An implementation of a Hybrid Hash Join.
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager) - 类 的构造器org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, int, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable.HashBucketIterator<BT,PT> - org.apache.flink.runtime.operators.hash中的类
 
MutableHashTable.ProbeIterator<PT> - org.apache.flink.runtime.operators.hash中的类
 
MutableHashTable.UnmatchedBuildIterator<BT,PT> - org.apache.flink.runtime.operators.hash中的类
Iterate all the elements in memory which has not been probed during probe phase.
MutableIOMetrics - org.apache.flink.runtime.rest.handler.util中的类
This class is a mutable version of the IOMetrics class that allows adding up IO-related metrics.
MutableIOMetrics() - 类 的构造器org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
MutableReader<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.reader中的接口
A record-oriented reader for mutable record types.
MutableRecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.reader中的类
Implementation of the record-oriented reader for mutable record types.
MutableRecordReader(InputGate, String[]) - 类 的构造器org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
Creates a new MutableRecordReader that de-serializes records from the given input gate and can spill partial records to disk, if they grow large.

N

name() - 类 中的方法org.apache.flink.runtime.checkpoint.MasterState
 
name - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump
The name of the stored metric.
name - 类 中的变量org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
The name of the state
namespaceSerializer - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapState
 
NestedMapsStateTable<K,N,S> - org.apache.flink.runtime.state.heap中的类
This implementation of StateTable uses nested HashMap objects.
NestedMapsStateTable(InternalKeyContext<K>, RegisteredKeyValueStateBackendMetaInfo<N, S>) - 类 的构造器org.apache.flink.runtime.state.heap.NestedMapsStateTable
Creates a new NestedMapsStateTable for the given key context and meta info.
netRuntime(long) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
NettyBufferPool - org.apache.flink.runtime.io.network.netty中的类
Extends around Netty's PooledByteBufAllocator with strict control over the number of created arenas.
NettyBufferPool(int) - 类 的构造器org.apache.flink.runtime.io.network.netty.NettyBufferPool
Creates Netty's buffer pool with the specified number of direct arenas.
NettyConfig - org.apache.flink.runtime.io.network.netty中的类
 
NettyConfig(InetAddress, int, int, int, Configuration) - 类 的构造器org.apache.flink.runtime.io.network.netty.NettyConfig
 
nettyConfig() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NettyConnectionManager - org.apache.flink.runtime.io.network.netty中的类
 
NettyConnectionManager(NettyConfig) - 类 的构造器org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
NettyMessage - org.apache.flink.runtime.io.network.netty中的类
A simple and generic interface to serialize messages to Netty's buffer space.
NettyMessage() - 类 的构造器org.apache.flink.runtime.io.network.netty.NettyMessage
 
NettyProtocol - org.apache.flink.runtime.io.network.netty中的类
Defines the server and client channel handlers, i.e. the protocol, used by netty.
NetworkBuffer - org.apache.flink.runtime.io.network.buffer中的类
Wrapper for pooled MemorySegment instances.
NetworkBuffer(MemorySegment, BufferRecycler) - 类 的构造器org.apache.flink.runtime.io.network.buffer.NetworkBuffer
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and writerIndex.
NetworkBuffer(MemorySegment, BufferRecycler, boolean) - 类 的构造器org.apache.flink.runtime.io.network.buffer.NetworkBuffer
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and writerIndex.
NetworkBuffer(MemorySegment, BufferRecycler, boolean, int) - 类 的构造器org.apache.flink.runtime.io.network.buffer.NetworkBuffer
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and size as writerIndex.
NetworkBufferPool - org.apache.flink.runtime.io.network.buffer中的类
The NetworkBufferPool is a fixed size pool of MemorySegment instances for the network stack.
NetworkBufferPool(int, int) - 类 的构造器org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
Allocates all MemorySegment instances managed by this pool.
networkBufferSize() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBuffersPerChannel() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufFraction() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMax() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMin() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NetworkClientHandler - org.apache.flink.runtime.io.network中的接口
Channel handler to read and write network messages on client side.
NetworkEnvironment - org.apache.flink.runtime.io.network中的类
Network I/O components of each TaskManager instance.
NetworkEnvironment(int, int, int, int, int, int, boolean) - 类 的构造器org.apache.flink.runtime.io.network.NetworkEnvironment
 
NetworkEnvironment(NetworkBufferPool, ConnectionManager, ResultPartitionManager, TaskEventDispatcher, KvStateRegistry, KvStateServer, KvStateClientProxy, IOManager.IOMode, int, int, int, int, boolean) - 类 的构造器org.apache.flink.runtime.io.network.NetworkEnvironment
 
NetworkEnvironmentConfiguration - org.apache.flink.runtime.taskmanager中的类
Configuration object for the network stack.
NetworkEnvironmentConfiguration(float, long, long, int, IOManager.IOMode, int, int, int, int) - 类 的构造器org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
Constructor for a setup with purely local communication (no netty).
NetworkEnvironmentConfiguration(float, long, long, int, IOManager.IOMode, int, int, int, int, NettyConfig) - 类 的构造器org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NetworkSequenceViewReader - org.apache.flink.runtime.io.network中的接口
Simple wrapper for the partition readerQueue iterator, which increments a sequence number for each returned buffer and remembers the receiver ID.
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
newBuilder() - 类 中的静态方法org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
newDirectExecutorService() - 类 中的静态方法org.apache.flink.runtime.concurrent.Executors
Return a new direct executor service.
newDynamicPropertiesOption() - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Get an instance of the dynamic properties option.
newInstanceAvailable(Instance) - 接口 中的方法org.apache.flink.runtime.instance.InstanceListener
Called when a new instance becomes available.
newInstanceAvailable(Instance) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
NewLeaderAvailable - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the Flink resource manager to indicate that a new leader is available.
NewLeaderAvailable(String, UUID) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
newSlotAvailable(Instance) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
newSlotAvailable(Instance) - 接口 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotAvailabilityListener
 
newThread(Runnable) - 类 中的方法org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
newThread(Runnable) - 类 中的方法org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
 
newThread(Runnable) - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory
 
next(E) - 类 中的方法org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next() - 类 中的方法org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next(E) - 类 中的方法org.apache.flink.runtime.io.disk.InputViewIterator
 
next() - 类 中的方法org.apache.flink.runtime.io.disk.InputViewIterator
 
next() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
 
next(T) - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.MutableReader
 
next(T) - 类 中的方法org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
 
next() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.Reader
 
next() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.RecordReader
 
next(BT) - 类 中的方法org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - 类 中的方法org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
next(T) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
 
next(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
next(BT) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
 
next(BT) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next(T) - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
next(T) - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
next(E) - 类 中的方法org.apache.flink.runtime.operators.sort.MergeIterator
Gets the next smallest element, with respect to the definition of order implied by the TypeSerializer provided to this iterator.
next() - 类 中的方法org.apache.flink.runtime.operators.sort.MergeIterator
Gets the next smallest element, with respect to the definition of order implied by the TypeSerializer provided to this iterator.
next() - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
next() - 接口 中的方法org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Moves the internal pointer to the next key (if present).
next() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
next(IN) - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next(T) - 类 中的方法org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - 类 中的方法org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - 类 中的方法org.apache.flink.runtime.util.EmptyIterator
Always throws a NoSuchElementException.
next(E) - 类 中的方法org.apache.flink.runtime.util.EmptyMutableObjectIterator
Always returns null.
next() - 类 中的方法org.apache.flink.runtime.util.EmptyMutableObjectIterator
Always returns null.
next() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
next() - 类 中的方法org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
next(T) - 类 中的方法org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
next() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
Prior to call this method, call hasNext() once!
next() - 类 中的方法org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
next() - 类 中的方法org.apache.flink.runtime.util.SingleElementIterator
 
nextBlock() - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
nextBlock() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nextBlock() - 接口 中的方法org.apache.flink.runtime.util.MemoryBlockIterator
Move the iterator to the next memory block.
nextBufferIsEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
nextBufferIsEvent() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Returns whether the next buffer is an event or not.
nextElement - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nextEntries() - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
Return some next entries which are available at the moment.
nextKey() - 接口 中的方法org.apache.flink.runtime.util.KeyGroupedIterator
 
nextKey() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Moves the iterator to the next key.
nextKey() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Moves the iterator to the next key.
nextOverflowBucket - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
nextOverflowBucket - 类 中的变量org.apache.flink.runtime.operators.hash.InMemoryPartition
 
nextRecord() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelInputView
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelOutputView
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Gets the next segment from the asynchronous block reader.
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessInputView
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.io.disk.SpillingBuffer
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
The method by which concrete subclasses realize page crossing.
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
This method must return a segment.
nextSegment() - 类 中的方法org.apache.flink.runtime.memory.ListMemorySegmentSource
 
nextSegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer
 
nextSegment(MemorySegment) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
nextSegment() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
This is the method called by the partitions to request memory to serialize records.
nioBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
nioBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
nioBufferCount() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
nioBuffers(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
NO_ALLOCATION_ID - 类 中的静态变量org.apache.flink.runtime.instance.Slot
 
NO_CURRENT_KEY_GROUP - 类 中的静态变量org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_OFFSET_SET - 类 中的静态变量org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_SLOT_REQUEST_ID - 类 中的静态变量org.apache.flink.runtime.instance.Slot
 
NO_SLOT_SHARING_GROUP_ID - 类 中的静态变量org.apache.flink.runtime.instance.Slot
 
NO_STRINGS - 类 中的静态变量org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
NO_TRANSFORM - 接口 中的静态变量org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
 
NO_VALUES - 类 中的静态变量org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
nodeChanged() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
nodeChanged() - 类 中的方法org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
noLocality(ResourceProfile) - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile, without any locality requirements.
noMoreBlocks - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nonBlockingShutDown(long, TimeUnit, ActorRef...) - 类 中的静态方法org.apache.flink.runtime.akka.ActorUtils
Shuts the given Actor down in a non blocking fashion.
NonClosingCheckpointOutputStream<T extends StreamStateHandle> - org.apache.flink.runtime.state中的类
Abstract class to implement custom checkpoint output streams which should not be closable for user code.
NonClosingCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream) - 类 的构造器org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
NonClosingInputStreamDecorator - org.apache.flink.runtime.util中的类
Decorator for input streams that ignores calls to InputStream.close().
NonClosingInputStreamDecorator(InputStream) - 类 的构造器org.apache.flink.runtime.util.NonClosingInputStreamDecorator
 
NonClosingOutpusStreamDecorator - org.apache.flink.runtime.util中的类
Decorator for input streams that ignores calls to OutputStream.close().
NonClosingOutpusStreamDecorator(OutputStream) - 类 的构造器org.apache.flink.runtime.util.NonClosingOutpusStreamDecorator
 
none() - 类 中的静态方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
NonOffloaded() - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
 
NonOffloaded(SerializedValue<T>) - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
 
NonPersistentMetadataCheckpointStorageLocation - org.apache.flink.runtime.state.memory中的类
A checkpoint storage location for the MemoryStateBackend in case no durable persistence for metadata has been configured.
NonPersistentMetadataCheckpointStorageLocation(int) - 类 的构造器org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
 
NonReusingBlockResettableIterator<T> - org.apache.flink.runtime.operators.resettable中的类
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
NonReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
NonReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
NonReusingBuildFirstHashJoinIterator<V1,V2,O> - org.apache.flink.runtime.operators.hash中的类
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
NonReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - org.apache.flink.runtime.operators.hash中的类
 
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
 
NonReusingBuildSecondHashJoinIterator<V1,V2,O> - org.apache.flink.runtime.operators.hash中的类
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
NonReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - org.apache.flink.runtime.operators.hash中的类
 
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
 
NonReusingDeserializationDelegate<T> - org.apache.flink.runtime.plugable中的类
A DeserializationDelegate that always creates a new instance upon deserialization.
NonReusingDeserializationDelegate(TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
NonReusingKeyGroupedIterator<E> - org.apache.flink.runtime.util中的类
The key grouped iterator returns a key and all values that share the same key.
NonReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeComparator<E>) - 类 的构造器org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Initializes the KeyGroupedIterator.
NonReusingKeyGroupedIterator.ValuesIterator - org.apache.flink.runtime.util中的类
 
NonReusingMergeInnerJoinIterator<T1,T2,O> - org.apache.flink.runtime.operators.sort中的类
 
NonReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
NonReusingMergeOuterJoinIterator<T1,T2,O> - org.apache.flink.runtime.operators.sort中的类
 
NonReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
NonReusingMutableToRegularIteratorWrapper<T> - org.apache.flink.runtime.util中的类
This class wraps a MutableObjectIterator into a regular Iterator.
NonReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
NonReusingSortMergeCoGroupIterator<T1,T2> - org.apache.flink.runtime.operators.sort中的类
 
NonReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - 类 的构造器org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
NoOpChainedDriver<IT> - org.apache.flink.runtime.operators中的类
A chained driver that just passes on the input as the output
NoOpChainedDriver() - 类 的构造器org.apache.flink.runtime.operators.NoOpChainedDriver
 
NoOpDriver<T> - org.apache.flink.runtime.operators中的类
A driver that does nothing but forward data from its input to its output.
NoOpDriver() - 类 的构造器org.apache.flink.runtime.operators.NoOpDriver
 
NoOpMetricRegistry - org.apache.flink.runtime.metrics中的类
Metric registry which does nothing.
NoOpTaskLocalStateStoreImpl - org.apache.flink.runtime.state中的类
This class implements a TaskLocalStateStore with no functionality and is used when local recovery is disabled.
NoOrFixedIfCheckpointingEnabledRestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
Default restart strategy that resolves either to NoRestartStrategy or FixedDelayRestartStrategy depending if checkpointing was enabled.
NoOrFixedIfCheckpointingEnabledRestartStrategyFactory() - 类 的构造器org.apache.flink.runtime.executiongraph.restart.NoOrFixedIfCheckpointingEnabledRestartStrategyFactory
 
noRequirements() - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile that has no requirements.
NoResourceAvailableException - org.apache.flink.runtime.jobmanager.scheduler中的异常错误
 
NoResourceAvailableException() - 异常错误 的构造器org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(ScheduledUnit) - 异常错误 的构造器org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(int, int, int) - 异常错误 的构造器org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(String) - 异常错误 的构造器org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoRestartStrategy - org.apache.flink.runtime.executiongraph.restart中的类
Restart strategy which does not restart an ExecutionGraph.
NoRestartStrategy() - 类 的构造器org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
NoRestartStrategy.NoRestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
 
NoRestartStrategyFactory() - 类 的构造器org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
NormalizedKeySorter<T> - org.apache.flink.runtime.operators.sort中的类
 
NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
NOT_CONTAINED - 接口 中的静态变量org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
The index that indicates that a HeapPriorityQueueElement object is not contained in and managed by any HeapPriorityQueue.
notFound() - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Returns the fallback target for use when there's no match at Router.route(HttpMethod, String).
notFound(T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Sets the fallback target for use when there's no match at Router.route(HttpMethod, String).
NotFoundException - org.apache.flink.runtime.rest中的异常错误
A special exception that indicates that an element was not found and that the request should be answered with a 404 return code.
NotFoundException(String) - 异常错误 的构造器org.apache.flink.runtime.rest.NotFoundException
 
NotFoundException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.NotFoundException
 
NotificationListener - org.apache.flink.runtime.util.event中的接口
 
notifyAllocationFailure(AllocationID, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
notifyAllocationFailure(AllocationID, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Notifies that the allocation has failed.
notifyAllocationFailure(JobID, AllocationID, Exception) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Notifies that an allocation failure has occurred.
notifyBufferAvailable(Buffer) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferListener
Notification callback if a buffer is recycled and becomes available in buffer pool.
notifyBufferAvailable(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
The Buffer pool notifies this channel of an available floating buffer.
notifyBufferDestroyed() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferListener
Notification callback if the buffer provider is destroyed.
notifyBufferDestroyed() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
notifyChannelNonEmpty() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Notifies the owning SingleInputGate that this channel became non-empty.
notifyCheckpointComplete(long, long) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Notify the task of this execution about a completed checkpoint.
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Invoked when a checkpoint has been completed, i.e., when the checkpoint coordinator has received the notification from all participating tasks.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Notify the given task about a completed checkpoint.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
NotifyCheckpointComplete - org.apache.flink.runtime.messages.checkpoint中的类
This message is sent from the JobMaster to the TaskExecutor to tell a task that the checkpoint has been confirmed and that the task can commit the checkpoint to the outside world.
NotifyCheckpointComplete(JobID, ExecutionAttemptID, long, long) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
notifyCheckpointComplete(long) - 接口 中的方法org.apache.flink.runtime.state.CheckpointListener
This method is called as a notification once a distributed checkpoint has been completed.
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.runtime.state.TaskStateManagerImpl
Tracking when local state can be disposed.
notifyCheckpointComplete(long) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
notifyCreditAvailable(RemoteInputChannel) - 类 中的方法org.apache.flink.runtime.io.network.netty.PartitionRequestClient
 
notifyCreditAvailable(RemoteInputChannel) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkClientHandler
The credit begins to announce after receiving the sender's backlog from buffer response.
notifyDataAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.partition.BufferAvailabilityListener
Called whenever there might be new data available.
notifyDataAvailable() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
notifyDataAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyFatalError(String, Throwable) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
notifyFatalError(String, Throwable) - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about a fatal error occurred in the task.
notifyHeartbeatTimeout(ResourceID) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatListener
Callback which is called if a heartbeat for the machine identified by the given resource ID times out.
notifyInfoMessage(InfoMessage) - 接口 中的方法org.apache.flink.runtime.resourcemanager.InfoMessageListenerRpcGateway
Notifies when resource manager need to notify listener about InfoMessage
notifyInputGateNonEmpty(InputGate) - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGateListener
Notification callback if the input gate moves from zero to non-zero available input channels with data.
notifyInputGateNonEmpty(InputGate) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
notifyJobTimeout(JobID, UUID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Notify a job timeout.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - 接口 中的方法org.apache.flink.runtime.jobmaster.KvStateRegistryGateway
Notifies that queryable state has been registered.
notifyKvStateRegistered(JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - 类 中的方法org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about a registered KvState instance.
NotifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Notifies the JobManager about a registered InternalKvState instance.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - 接口 中的方法org.apache.flink.runtime.query.KvStateRegistryListener
Notifies the listener about a registered KvState instance.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 接口 中的方法org.apache.flink.runtime.jobmaster.KvStateRegistryGateway
Notifies that queryable state has been unregistered.
notifyKvStateUnregistered(JobVertexID, KeyGroupRange, String) - 类 中的方法org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about an unregistered KvState instance.
NotifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 类 的构造器org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Notifies the JobManager about an unregistered InternalKvState instance.
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 接口 中的方法org.apache.flink.runtime.query.KvStateRegistryListener
Notifies the listener about an unregistered KvState instance.
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
notifyLeaderAddress(String, UUID) - 接口 中的方法org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
This method is called by the LeaderRetrievalService when a new leader is elected.
notifyLeaderAddress(String, UUID) - 类 中的方法org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
notifyLeaderAddress(String, UUID) - 类 中的方法org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
notifyLeaderAddress(String, UUID) - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
notifyLeaderAddress(String, UUID) - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
notifyLeaderAddress(String, UUID) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
notifyListener(String, UUID) - 类 中的方法org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
notifyNewLeaderAddress(CompletableFuture<Tuple2<String, UUID>>) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
 
notifyNewLeaderAddress(CompletableFuture<Tuple2<String, UUID>>) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
notifyNewVertices(List<ExecutionJobVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called whenever new vertices are added to the ExecutionGraph.
notifyNewVertices(List<ExecutionJobVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
notifyOfAddedMetric(ActorRef, Metric, String, AbstractMetricGroup) - 类 中的静态方法org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of an added metric.
notifyOfAddedView(View) - 类 中的方法org.apache.flink.runtime.metrics.ViewUpdater
Notifies this ViewUpdater of a new metric that should be regularly updated.
notifyOfEndOfSuperstep() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
Called by iteration tail to signal that all input of a superstep has been processed (unblocks iteration head).
notifyOfRemovedMetric(ActorRef, Metric) - 类 中的静态方法org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of a removed metric.
notifyOfRemovedView(View) - 类 中的方法org.apache.flink.runtime.metrics.ViewUpdater
Notifies this ViewUpdater of a metric that should no longer be regularly updated.
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
NotifyResourceStarted - org.apache.flink.runtime.clusterframework.messages中的类
Notifies the ResourceManager that a TaskManager has been started in a container with the given resource id.
NotifyResourceStarted(ResourceID) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
notifySlotAvailable(InstanceID, SlotID, AllocationID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
notifySlotAvailable(InstanceID, SlotID, AllocationID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sent by the TaskExecutor to notify the ResourceManager that a slot has become available.
notifySolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Releases the waiting thread.
notifySubpartitionConsumed() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
notifySubpartitionConsumed() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyTimeout(AllocationID, UUID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
notifyTimeout(K, UUID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TimeoutListener
Notify the listener about the timeout for an event identified by key.
notLeader() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
noTransform() - 接口 中的静态方法org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
 
NUM_ARENAS - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_REGISTERED_TASK_MANAGERS - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
NUM_RUNNING_JOBS - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
NUM_THREADS_CLIENT - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_THREADS_SERVER - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
numberOfElements - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
Total number of input elements.
NumberOfFullRestartsGauge - org.apache.flink.runtime.executiongraph.metrics中的类
Gauge which returns the number of full restarts.
NumberOfFullRestartsGauge(ExecutionGraph) - 类 的构造器org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
numberOfKeyGroups - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
The number of key-groups aka max parallelism.
numberOfKeyGroups - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
numberOfWorkers() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
numBuckets - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The number of buckets in the current table.
numBuffersIn - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
numBytesIn - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
numBytesInLocal - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInLocalPerSecond - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemote - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemotePerSecond - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOut - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOutPerSecond - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numCounters - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numFetchRetries - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
The number of retries when the transfer fails.
numGauges - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numHashFunctions - 类 中的变量org.apache.flink.runtime.operators.util.BloomFilter
 
numHistograms - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numKeyValueStateEntries() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numKeyValueStateEntries() - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numKeyValueStateEntries(Object) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
Returns the total number of state entries across all keys for the given namespace.
numMeters - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numOverflowSegments - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
numOverflowSegments - 类 中的变量org.apache.flink.runtime.operators.hash.InMemoryPartition
 
numProxyQueryThreads() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the thread pool that performs the actual state lookup.
numProxyServerThreads() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the query server NIO event loop.
numRecordsIn - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsIn - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsInPerSecond - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsOutPerSecond - 类 中的变量org.apache.flink.runtime.executiongraph.IOMetrics
 
numRegisteredJobMetricGroups() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
numRegisteredJobMetricGroups() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
numRegisteredTaskManagers() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
numRequestsRemaining - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
numSlots() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
numStateQueryThreads() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the thread pool that performs the actual state lookup.
numStateServerThreads() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the query server NIO event loop.
numTargetKeyGroups - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultPartition
 
numWriteBuffersToCluster - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 

O

objectReuseEnabled - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
objectReuseEnabled - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Whether to reuse objects during deserialization.
occupySlot() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
of(int, OperatorID) - 类 中的静态方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
of(SlotInfo, Locality) - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
 
of(TriggerId, JobID) - 类 中的静态方法org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
 
of(OperatorBackPressureStats) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
 
of(T) - 类 中的静态方法org.apache.flink.runtime.state.DoneFuture
 
of(int, int) - 类 中的静态方法org.apache.flink.runtime.state.KeyGroupRange
Factory method that also handles creation of empty key-groups.
of(T) - 类 中的静态方法org.apache.flink.runtime.state.SnapshotResult
 
offer(E) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
offer(E) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
offer(T) - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds element to the PriorityQueue in log(size) time if either the PriorityQueue is not full, or not lessThan(element, top()).
offerSlots(ResourceID, Collection<SlotOffer>, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
offerSlots(ResourceID, Collection<SlotOffer>, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Offers the given slots to the job manager.
offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Offers multiple slots to the SlotPool.
offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
Offloaded() - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
 
Offloaded(PermanentBlobKey) - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
 
onAddedJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
onAddedJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances added by a different SubmittedJobGraphStore instance.
onBuffer(Buffer, int, int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
OnCompletionActions - org.apache.flink.runtime.jobmanager中的接口
Interface for completion actions once a Flink job has reached a terminal state.
onConsumedSubpartition() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Notifies the parent partition about a consumed ResultSubpartitionView.
onEmptyBuffer(int, int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onError(Throwable) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
OneTimeLeaderListenerFuture - org.apache.flink.runtime.minicluster中的类
A leader listener that exposes a future for the first leader notification.
OneTimeLeaderListenerFuture() - 类 的构造器org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
onEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
Barrier will release the waiting thread if an event occurs.
onEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.iterative.task.SyncEventHandler
 
onEvent(T) - 接口 中的方法org.apache.flink.runtime.util.event.EventListener
 
onExecutionFail(Execution, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
onFailedPartitionRequest() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onFatalError(Throwable) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
onFatalError(Throwable) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
onFatalError(Throwable) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Notifies the ResourceManager that a fatal error has occurred and it cannot proceed.
onFatalError(Throwable) - 接口 中的方法org.apache.flink.runtime.rpc.FatalErrorHandler
Being called when a fatal error occurs.
onFatalError(Throwable) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
onNotification() - 接口 中的方法org.apache.flink.runtime.util.event.NotificationListener
 
onReceive(Object) - 类 中的方法org.apache.flink.runtime.akka.FlinkUntypedActor
This method is called by Akka if a new message has arrived for the actor.
onReceive(Object) - 类 中的方法org.apache.flink.runtime.akka.QuarantineMonitor
 
onReceive(Object) - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricQueryService
 
onReceive(Object) - 类 中的方法org.apache.flink.runtime.process.ProcessReaper
 
onRegistrationFailure(Throwable) - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
This method handle the Registration failure.
onRegistrationFailure(Throwable) - 接口 中的方法org.apache.flink.runtime.registration.RegistrationConnectionListener
This method is called by the RegisteredRpcConnection when the registration fails.
onRegistrationFailure(Throwable) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
onRegistrationSuccess(S) - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
This method handle the Registration Response.
onRegistrationSuccess(T, S) - 接口 中的方法org.apache.flink.runtime.registration.RegistrationConnectionListener
This method is called by the RegisteredRpcConnection when the registration is success.
onRegistrationSuccess(TaskExecutorRegistrationSuccess) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
onRemovedJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
onRemovedJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances removed by a different SubmittedJobGraphStore instance.
onStart() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
onStart() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
onStart() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
User overridable callback.
onStart() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
onStop() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
onStop() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
Suspend the job and shutdown all other services including rpc.
onStop() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
onStop() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
User overridable callback.
onStop() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
Called to shut down the TaskManager.
onTaskFailure(Execution, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called by the execution graph when a task failure occurs.
onTaskFailure(Execution, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
onTaskFailure(Execution, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
onTaskFailure(Execution, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
open() - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Initialize the hash table
open() - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable
Initialize the hash table
open() - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Initialize the hash table
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Opens the hash join.
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Opens the hash join.
open() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
open() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
open() - 类 中的方法org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
open() - 接口 中的方法org.apache.flink.runtime.operators.util.CoGroupTaskIterator
General-purpose open method.
open() - 接口 中的方法org.apache.flink.runtime.operators.util.JoinTaskIterator
General-purpose open method.
openChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Opens all chained tasks, in the order as they are stored in the array.
openInputStream() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
 
openInputStream() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
openInputStream() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
openInputStream() - 接口 中的方法org.apache.flink.runtime.state.OperatorStateHandle
Returns an input stream to read the operator state information.
openInputStream() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
openInputStream() - 类 中的方法org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
openInputStream() - 类 中的方法org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
openInputStream() - 接口 中的方法org.apache.flink.runtime.state.StreamStateHandle
Returns an FSDataInputStream that can be used to read back the data that was previously written to the stream.
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
openTask() - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
openUserCode(Function, Configuration) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
Opens the given stub using its RichFunction.open(Configuration) method.
OperationKey - org.apache.flink.runtime.rest.handler.async中的类
Any operation key for the AbstractAsynchronousOperationHandlers must extend this class.
OperationKey(TriggerId) - 类 的构造器org.apache.flink.runtime.rest.handler.async.OperationKey
 
operationResultResponse(R) - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
Create the operation result from the given value.
operationResultResponse(Acknowledge) - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
 
operationResultResponse(Acknowledge) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
 
operationResultResponse(String) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
OperatorBackendSerializationProxy - org.apache.flink.runtime.state中的类
Serialization proxy for all meta data in operator state backends.
OperatorBackendSerializationProxy(ClassLoader) - 类 的构造器org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
OperatorBackendSerializationProxy(List<StateMetaInfoSnapshot>, List<StateMetaInfoSnapshot>) - 类 的构造器org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
OperatorBackendStateMetaInfoReaderV1() - 类 的构造器org.apache.flink.runtime.state.metainfo.LegacyStateMetaInfoReaders.OperatorBackendStateMetaInfoReaderV1
 
OperatorBackPressureStats - org.apache.flink.runtime.rest.handler.legacy.backpressure中的类
Back pressure statistics of multiple tasks.
OperatorBackPressureStats(int, long, double[]) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
 
OperatorBackPressureStatsResponse - org.apache.flink.runtime.rest.handler.legacy.backpressure中的类
OperatorID - org.apache.flink.runtime.jobgraph中的类
A class for statistically unique operator IDs.
OperatorID() - 类 的构造器org.apache.flink.runtime.jobgraph.OperatorID
 
OperatorID(byte[]) - 类 的构造器org.apache.flink.runtime.jobgraph.OperatorID
 
OperatorID(long, long) - 类 的构造器org.apache.flink.runtime.jobgraph.OperatorID
 
OperatorInstanceID - org.apache.flink.runtime.jobgraph中的类
An ID for physical instance of the operator.
OperatorInstanceID(int, OperatorID) - 类 的构造器org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
OperatorIOMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Metric group that contains shareable pre-defined IO-related metrics.
OperatorIOMetricGroup(OperatorMetricGroup) - 类 的构造器org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
OperatorMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing an Operator.
OperatorMetricGroup(MetricRegistry, TaskMetricGroup, OperatorID, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
operatorName - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, int, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, int, String, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the OperatorMetricGroup.
OperatorScopeFormat(String, TaskScopeFormat) - 类 的构造器org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
OperatorState - org.apache.flink.runtime.checkpoint中的类
Simple container class which contains the raw/managed operator state and key-group state handles from all sub tasks of an operator and therefore represents the complete state of a logical operator.
OperatorState(OperatorID, int, int) - 类 的构造器org.apache.flink.runtime.checkpoint.OperatorState
 
OperatorStateBackend - org.apache.flink.runtime.state中的接口
Interface that combines both, the user facing OperatorStateStore interface and the system interface SnapshotStrategy
OperatorStateCheckpointOutputStream - org.apache.flink.runtime.state中的类
Checkpoint output stream that allows to write raw operator state in a partitioned way.
OperatorStateCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream) - 类 的构造器org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
 
OperatorStateHandle - org.apache.flink.runtime.state中的接口
Interface of a state handle for operator state.
OperatorStateHandle.Mode - org.apache.flink.runtime.state中的枚举
The modes that determine how an OperatorStreamStateHandle is assigned to tasks during restore.
OperatorStateHandle.StateMetaInfo - org.apache.flink.runtime.state中的类
Meta information about the operator state handle.
OperatorStateRepartitioner - org.apache.flink.runtime.checkpoint中的接口
Interface that allows to implement different strategies for repartitioning of operator state as parallelism changes.
OperatorStateRestoreOperation - org.apache.flink.runtime.state中的类
Implementation of operator state restore operation.
OperatorStateRestoreOperation(CloseableRegistry, ClassLoader, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, Collection<OperatorStateHandle>) - 类 的构造器org.apache.flink.runtime.state.OperatorStateRestoreOperation
 
OperatorStreamStateHandle - org.apache.flink.runtime.state中的类
State handle for partitionable operator state.
OperatorStreamStateHandle(Map<String, OperatorStateHandle.StateMetaInfo>, StreamStateHandle) - 类 的构造器org.apache.flink.runtime.state.OperatorStreamStateHandle
 
OperatorSubtaskDescriptionText - org.apache.flink.runtime.util中的类
This class generates a string that can be used to identify an operator subtask.
OperatorSubtaskDescriptionText(OperatorID, String, int, int) - 类 的构造器org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
 
OperatorSubtaskState - org.apache.flink.runtime.checkpoint中的类
This class encapsulates the state for one parallel instance of an operator.
OperatorSubtaskState() - 类 的构造器org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Empty state.
OperatorSubtaskState(StateObjectCollection<OperatorStateHandle>, StateObjectCollection<OperatorStateHandle>, StateObjectCollection<KeyedStateHandle>, StateObjectCollection<KeyedStateHandle>) - 类 的构造器org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
OperatorSubtaskState(OperatorStateHandle, OperatorStateHandle, KeyedStateHandle, KeyedStateHandle) - 类 的构造器org.apache.flink.runtime.checkpoint.OperatorSubtaskState
For convenience because the size of the collections is typically 0 or 1.
operatorSubtaskStateFrom(OperatorInstanceID, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<KeyedStateHandle>>, Map<OperatorInstanceID, List<KeyedStateHandle>>) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
optimalNumOfBits(long, double) - 类 中的静态方法org.apache.flink.runtime.operators.util.BloomFilter
Compute optimal bits number with given input entries and expected false positive probability.
order() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
org.apache.flink.runtime - 程序包 org.apache.flink.runtime
 
org.apache.flink.runtime.accumulators - 程序包 org.apache.flink.runtime.accumulators
 
org.apache.flink.runtime.akka - 程序包 org.apache.flink.runtime.akka
 
org.apache.flink.runtime.blob - 程序包 org.apache.flink.runtime.blob
 
org.apache.flink.runtime.broadcast - 程序包 org.apache.flink.runtime.broadcast
 
org.apache.flink.runtime.checkpoint - 程序包 org.apache.flink.runtime.checkpoint
 
org.apache.flink.runtime.checkpoint.decline - 程序包 org.apache.flink.runtime.checkpoint.decline
 
org.apache.flink.runtime.checkpoint.hooks - 程序包 org.apache.flink.runtime.checkpoint.hooks
 
org.apache.flink.runtime.checkpoint.savepoint - 程序包 org.apache.flink.runtime.checkpoint.savepoint
 
org.apache.flink.runtime.client - 程序包 org.apache.flink.runtime.client
 
org.apache.flink.runtime.clusterframework - 程序包 org.apache.flink.runtime.clusterframework
This package contains the cluster resource management functionality.
org.apache.flink.runtime.clusterframework.messages - 程序包 org.apache.flink.runtime.clusterframework.messages
This package contains the actor messages that are sent between the cluster resource framework and the JobManager, as well as the generic messages sent between the cluster resource framework and the client.
org.apache.flink.runtime.clusterframework.overlays - 程序包 org.apache.flink.runtime.clusterframework.overlays
 
org.apache.flink.runtime.clusterframework.types - 程序包 org.apache.flink.runtime.clusterframework.types
 
org.apache.flink.runtime.concurrent - 程序包 org.apache.flink.runtime.concurrent
 
org.apache.flink.runtime.concurrent.akka - 程序包 org.apache.flink.runtime.concurrent.akka
 
org.apache.flink.runtime.deployment - 程序包 org.apache.flink.runtime.deployment
 
org.apache.flink.runtime.dispatcher - 程序包 org.apache.flink.runtime.dispatcher
 
org.apache.flink.runtime.entrypoint - 程序包 org.apache.flink.runtime.entrypoint
 
org.apache.flink.runtime.entrypoint.component - 程序包 org.apache.flink.runtime.entrypoint.component
 
org.apache.flink.runtime.entrypoint.parser - 程序包 org.apache.flink.runtime.entrypoint.parser
 
org.apache.flink.runtime.event - 程序包 org.apache.flink.runtime.event
 
org.apache.flink.runtime.execution - 程序包 org.apache.flink.runtime.execution
 
org.apache.flink.runtime.execution.librarycache - 程序包 org.apache.flink.runtime.execution.librarycache
 
org.apache.flink.runtime.executiongraph - 程序包 org.apache.flink.runtime.executiongraph
 
org.apache.flink.runtime.executiongraph.failover - 程序包 org.apache.flink.runtime.executiongraph.failover
 
org.apache.flink.runtime.executiongraph.metrics - 程序包 org.apache.flink.runtime.executiongraph.metrics
This package contains classes implementing various metrics for the job execution, based on the Execution Graph.
org.apache.flink.runtime.executiongraph.restart - 程序包 org.apache.flink.runtime.executiongraph.restart
 
org.apache.flink.runtime.filecache - 程序包 org.apache.flink.runtime.filecache
 
org.apache.flink.runtime.heartbeat - 程序包 org.apache.flink.runtime.heartbeat
 
org.apache.flink.runtime.highavailability - 程序包 org.apache.flink.runtime.highavailability
 
org.apache.flink.runtime.highavailability.nonha - 程序包 org.apache.flink.runtime.highavailability.nonha
 
org.apache.flink.runtime.highavailability.nonha.embedded - 程序包 org.apache.flink.runtime.highavailability.nonha.embedded
 
org.apache.flink.runtime.highavailability.nonha.leaderelection - 程序包 org.apache.flink.runtime.highavailability.nonha.leaderelection
 
org.apache.flink.runtime.highavailability.nonha.standalone - 程序包 org.apache.flink.runtime.highavailability.nonha.standalone
 
org.apache.flink.runtime.highavailability.zookeeper - 程序包 org.apache.flink.runtime.highavailability.zookeeper
 
org.apache.flink.runtime.history - 程序包 org.apache.flink.runtime.history
 
org.apache.flink.runtime.instance - 程序包 org.apache.flink.runtime.instance
 
org.apache.flink.runtime.io.disk - 程序包 org.apache.flink.runtime.io.disk
 
org.apache.flink.runtime.io.disk.iomanager - 程序包 org.apache.flink.runtime.io.disk.iomanager
 
org.apache.flink.runtime.io.network - 程序包 org.apache.flink.runtime.io.network
 
org.apache.flink.runtime.io.network.api - 程序包 org.apache.flink.runtime.io.network.api
 
org.apache.flink.runtime.io.network.api.reader - 程序包 org.apache.flink.runtime.io.network.api.reader
 
org.apache.flink.runtime.io.network.api.serialization - 程序包 org.apache.flink.runtime.io.network.api.serialization
 
org.apache.flink.runtime.io.network.api.writer - 程序包 org.apache.flink.runtime.io.network.api.writer
 
org.apache.flink.runtime.io.network.buffer - 程序包 org.apache.flink.runtime.io.network.buffer
 
org.apache.flink.runtime.io.network.netty - 程序包 org.apache.flink.runtime.io.network.netty
 
org.apache.flink.runtime.io.network.netty.exception - 程序包 org.apache.flink.runtime.io.network.netty.exception
 
org.apache.flink.runtime.io.network.partition - 程序包 org.apache.flink.runtime.io.network.partition
 
org.apache.flink.runtime.io.network.partition.consumer - 程序包 org.apache.flink.runtime.io.network.partition.consumer
 
org.apache.flink.runtime.iterative.concurrent - 程序包 org.apache.flink.runtime.iterative.concurrent
 
org.apache.flink.runtime.iterative.convergence - 程序包 org.apache.flink.runtime.iterative.convergence
 
org.apache.flink.runtime.iterative.event - 程序包 org.apache.flink.runtime.iterative.event
 
org.apache.flink.runtime.iterative.io - 程序包 org.apache.flink.runtime.iterative.io
 
org.apache.flink.runtime.iterative.task - 程序包 org.apache.flink.runtime.iterative.task
 
org.apache.flink.runtime.jobgraph - 程序包 org.apache.flink.runtime.jobgraph
 
org.apache.flink.runtime.jobgraph.jsonplan - 程序包 org.apache.flink.runtime.jobgraph.jsonplan
 
org.apache.flink.runtime.jobgraph.tasks - 程序包 org.apache.flink.runtime.jobgraph.tasks
 
org.apache.flink.runtime.jobmanager - 程序包 org.apache.flink.runtime.jobmanager
 
org.apache.flink.runtime.jobmanager.scheduler - 程序包 org.apache.flink.runtime.jobmanager.scheduler
 
org.apache.flink.runtime.jobmanager.slots - 程序包 org.apache.flink.runtime.jobmanager.slots
 
org.apache.flink.runtime.jobmaster - 程序包 org.apache.flink.runtime.jobmaster
 
org.apache.flink.runtime.jobmaster.exceptions - 程序包 org.apache.flink.runtime.jobmaster.exceptions
 
org.apache.flink.runtime.jobmaster.factories - 程序包 org.apache.flink.runtime.jobmaster.factories
 
org.apache.flink.runtime.jobmaster.message - 程序包 org.apache.flink.runtime.jobmaster.message
 
org.apache.flink.runtime.jobmaster.slotpool - 程序包 org.apache.flink.runtime.jobmaster.slotpool
 
org.apache.flink.runtime.leaderelection - 程序包 org.apache.flink.runtime.leaderelection
 
org.apache.flink.runtime.leaderretrieval - 程序包 org.apache.flink.runtime.leaderretrieval
 
org.apache.flink.runtime.memory - 程序包 org.apache.flink.runtime.memory
 
org.apache.flink.runtime.messages - 程序包 org.apache.flink.runtime.messages
This package contains the messages that are sent between Flink's distributed components to coordinate the distributed operations.
org.apache.flink.runtime.messages.checkpoint - 程序包 org.apache.flink.runtime.messages.checkpoint
This package contains the messages that are sent between JobMaster and TaskExecutor to coordinate the checkpoint snapshots of the distributed dataflow.
org.apache.flink.runtime.messages.webmonitor - 程序包 org.apache.flink.runtime.messages.webmonitor
This package contains the actor messages that are sent between the JobManager and components that are interested in the status of the JobManager.
org.apache.flink.runtime.metrics - 程序包 org.apache.flink.runtime.metrics
 
org.apache.flink.runtime.metrics.dump - 程序包 org.apache.flink.runtime.metrics.dump
 
org.apache.flink.runtime.metrics.groups - 程序包 org.apache.flink.runtime.metrics.groups
 
org.apache.flink.runtime.metrics.scope - 程序包 org.apache.flink.runtime.metrics.scope
 
org.apache.flink.runtime.metrics.util - 程序包 org.apache.flink.runtime.metrics.util
 
org.apache.flink.runtime.minicluster - 程序包 org.apache.flink.runtime.minicluster
 
org.apache.flink.runtime.net - 程序包 org.apache.flink.runtime.net
 
org.apache.flink.runtime.operators - 程序包 org.apache.flink.runtime.operators
 
org.apache.flink.runtime.operators.chaining - 程序包 org.apache.flink.runtime.operators.chaining
 
org.apache.flink.runtime.operators.hash - 程序包 org.apache.flink.runtime.operators.hash
 
org.apache.flink.runtime.operators.resettable - 程序包 org.apache.flink.runtime.operators.resettable
 
org.apache.flink.runtime.operators.shipping - 程序包 org.apache.flink.runtime.operators.shipping
 
org.apache.flink.runtime.operators.sort - 程序包 org.apache.flink.runtime.operators.sort
 
org.apache.flink.runtime.operators.udf - 程序包 org.apache.flink.runtime.operators.udf
 
org.apache.flink.runtime.operators.util - 程序包 org.apache.flink.runtime.operators.util
 
org.apache.flink.runtime.operators.util.metrics - 程序包 org.apache.flink.runtime.operators.util.metrics
 
org.apache.flink.runtime.plugable - 程序包 org.apache.flink.runtime.plugable
 
org.apache.flink.runtime.process - 程序包 org.apache.flink.runtime.process
 
org.apache.flink.runtime.query - 程序包 org.apache.flink.runtime.query
 
org.apache.flink.runtime.registration - 程序包 org.apache.flink.runtime.registration
 
org.apache.flink.runtime.resourcemanager - 程序包 org.apache.flink.runtime.resourcemanager
 
org.apache.flink.runtime.resourcemanager.exceptions - 程序包 org.apache.flink.runtime.resourcemanager.exceptions
 
org.apache.flink.runtime.resourcemanager.registration - 程序包 org.apache.flink.runtime.resourcemanager.registration
 
org.apache.flink.runtime.resourcemanager.slotmanager - 程序包 org.apache.flink.runtime.resourcemanager.slotmanager
 
org.apache.flink.runtime.rest - 程序包 org.apache.flink.runtime.rest
 
org.apache.flink.runtime.rest.handler - 程序包 org.apache.flink.runtime.rest.handler
 
org.apache.flink.runtime.rest.handler.async - 程序包 org.apache.flink.runtime.rest.handler.async
 
org.apache.flink.runtime.rest.handler.cluster - 程序包 org.apache.flink.runtime.rest.handler.cluster
 
org.apache.flink.runtime.rest.handler.job - 程序包 org.apache.flink.runtime.rest.handler.job
 
org.apache.flink.runtime.rest.handler.job.checkpoints - 程序包 org.apache.flink.runtime.rest.handler.job.checkpoints
 
org.apache.flink.runtime.rest.handler.job.metrics - 程序包 org.apache.flink.runtime.rest.handler.job.metrics
 
org.apache.flink.runtime.rest.handler.job.rescaling - 程序包 org.apache.flink.runtime.rest.handler.job.rescaling
 
org.apache.flink.runtime.rest.handler.job.savepoints - 程序包 org.apache.flink.runtime.rest.handler.job.savepoints
 
org.apache.flink.runtime.rest.handler.legacy - 程序包 org.apache.flink.runtime.rest.handler.legacy
 
org.apache.flink.runtime.rest.handler.legacy.backpressure - 程序包 org.apache.flink.runtime.rest.handler.legacy.backpressure
 
org.apache.flink.runtime.rest.handler.legacy.files - 程序包 org.apache.flink.runtime.rest.handler.legacy.files
 
org.apache.flink.runtime.rest.handler.legacy.messages - 程序包 org.apache.flink.runtime.rest.handler.legacy.messages
 
org.apache.flink.runtime.rest.handler.legacy.metrics - 程序包 org.apache.flink.runtime.rest.handler.legacy.metrics
 
org.apache.flink.runtime.rest.handler.router - 程序包 org.apache.flink.runtime.rest.handler.router
 
org.apache.flink.runtime.rest.handler.taskmanager - 程序包 org.apache.flink.runtime.rest.handler.taskmanager
 
org.apache.flink.runtime.rest.handler.util - 程序包 org.apache.flink.runtime.rest.handler.util
 
org.apache.flink.runtime.rest.messages - 程序包 org.apache.flink.runtime.rest.messages
 
org.apache.flink.runtime.rest.messages.checkpoints - 程序包 org.apache.flink.runtime.rest.messages.checkpoints
 
org.apache.flink.runtime.rest.messages.cluster - 程序包 org.apache.flink.runtime.rest.messages.cluster
 
org.apache.flink.runtime.rest.messages.job - 程序包 org.apache.flink.runtime.rest.messages.job
 
org.apache.flink.runtime.rest.messages.job.metrics - 程序包 org.apache.flink.runtime.rest.messages.job.metrics
 
org.apache.flink.runtime.rest.messages.job.savepoints - 程序包 org.apache.flink.runtime.rest.messages.job.savepoints
 
org.apache.flink.runtime.rest.messages.json - 程序包 org.apache.flink.runtime.rest.messages.json
 
org.apache.flink.runtime.rest.messages.queue - 程序包 org.apache.flink.runtime.rest.messages.queue
 
org.apache.flink.runtime.rest.messages.taskmanager - 程序包 org.apache.flink.runtime.rest.messages.taskmanager
 
org.apache.flink.runtime.rest.util - 程序包 org.apache.flink.runtime.rest.util
 
org.apache.flink.runtime.rest.versioning - 程序包 org.apache.flink.runtime.rest.versioning
 
org.apache.flink.runtime.rpc - 程序包 org.apache.flink.runtime.rpc
 
org.apache.flink.runtime.rpc.akka - 程序包 org.apache.flink.runtime.rpc.akka
 
org.apache.flink.runtime.rpc.akka.exceptions - 程序包 org.apache.flink.runtime.rpc.akka.exceptions
 
org.apache.flink.runtime.rpc.exceptions - 程序包 org.apache.flink.runtime.rpc.exceptions
 
org.apache.flink.runtime.rpc.messages - 程序包 org.apache.flink.runtime.rpc.messages
 
org.apache.flink.runtime.security - 程序包 org.apache.flink.runtime.security
 
org.apache.flink.runtime.security.modules - 程序包 org.apache.flink.runtime.security.modules
 
org.apache.flink.runtime.state - 程序包 org.apache.flink.runtime.state
 
org.apache.flink.runtime.state.filesystem - 程序包 org.apache.flink.runtime.state.filesystem
 
org.apache.flink.runtime.state.heap - 程序包 org.apache.flink.runtime.state.heap
This package contains the classes for key/value state backends that store the state on the JVM heap as objects.
org.apache.flink.runtime.state.internal - 程序包 org.apache.flink.runtime.state.internal
This package holds the classes of the internal state type hierarchy.
org.apache.flink.runtime.state.memory - 程序包 org.apache.flink.runtime.state.memory
 
org.apache.flink.runtime.state.metainfo - 程序包 org.apache.flink.runtime.state.metainfo
 
org.apache.flink.runtime.state.ttl - 程序包 org.apache.flink.runtime.state.ttl
 
org.apache.flink.runtime.taskexecutor - 程序包 org.apache.flink.runtime.taskexecutor
 
org.apache.flink.runtime.taskexecutor.exceptions - 程序包 org.apache.flink.runtime.taskexecutor.exceptions
 
org.apache.flink.runtime.taskexecutor.rpc - 程序包 org.apache.flink.runtime.taskexecutor.rpc
 
org.apache.flink.runtime.taskexecutor.slot - 程序包 org.apache.flink.runtime.taskexecutor.slot
 
org.apache.flink.runtime.taskmanager - 程序包 org.apache.flink.runtime.taskmanager
 
org.apache.flink.runtime.throwable - 程序包 org.apache.flink.runtime.throwable
 
org.apache.flink.runtime.types - 程序包 org.apache.flink.runtime.types
 
org.apache.flink.runtime.util - 程序包 org.apache.flink.runtime.util
 
org.apache.flink.runtime.util.clock - 程序包 org.apache.flink.runtime.util.clock
 
org.apache.flink.runtime.util.event - 程序包 org.apache.flink.runtime.util.event
 
org.apache.flink.runtime.webmonitor - 程序包 org.apache.flink.runtime.webmonitor
 
org.apache.flink.runtime.webmonitor.history - 程序包 org.apache.flink.runtime.webmonitor.history
 
org.apache.flink.runtime.webmonitor.retriever - 程序包 org.apache.flink.runtime.webmonitor.retriever
 
org.apache.flink.runtime.webmonitor.retriever.impl - 程序包 org.apache.flink.runtime.webmonitor.retriever.impl
 
org.apache.flink.runtime.zookeeper - 程序包 org.apache.flink.runtime.zookeeper
 
org.apache.flink.runtime.zookeeper.filesystem - 程序包 org.apache.flink.runtime.zookeeper.filesystem
 
orTimeout(CompletableFuture<T>, long, TimeUnit) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, Executor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Times the given future out after the timeout.
outerJoinIterator - 类 中的变量org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
output - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The collector that forwards the user code's results.
outputCollector - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
OutputCollector<T> - org.apache.flink.runtime.operators.shipping中的类
The OutputCollector collects records, and emits them to the RecordWriters.
OutputCollector(List<RecordWriter<SerializationDelegate<T>>>, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.operators.shipping.OutputCollector
Initializes the output collector with a set of writers.
OutputEmitter<T> - org.apache.flink.runtime.operators.shipping中的类
The output emitter decides to which of the possibly multiple output channels a record is sent.
OutputEmitter(ShipStrategyType, int) - 类 的构造器org.apache.flink.runtime.operators.shipping.OutputEmitter
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...)
OutputEmitter(ShipStrategyType, TypeComparator<T>) - 类 的构造器org.apache.flink.runtime.operators.shipping.OutputEmitter
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...)
OutputEmitter(ShipStrategyType, int, TypeComparator<T>, Partitioner<?>, DataDistribution) - 类 的构造器org.apache.flink.runtime.operators.shipping.OutputEmitter
 
OutputFormatVertex - org.apache.flink.runtime.jobgraph中的类
A task vertex that run an initialization on the master, trying to deserialize an output format and initializing it on master, if necessary.
OutputFormatVertex(String) - 类 的构造器org.apache.flink.runtime.jobgraph.OutputFormatVertex
Creates a new task vertex with the specified name.
overflowSegments - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
overflowSegments - 类 中的变量org.apache.flink.runtime.operators.hash.InMemoryPartition
 
overwriteRecordAt(long, T) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
已过时。
Don't use this, overwrites record and causes inconsistency or data loss for overwriting everything but records of the exact same size
OwnedTaskLocalStateStore - org.apache.flink.runtime.state中的接口
This interface represents the administrative interface to TaskLocalStateStore, that only the owner of the object should see.

P

p75 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p90 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p95 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p98 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p99 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p999 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
pairComparator - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
pairComparator - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
PARALLELISM_AUTO_MAX_ERROR_MESSAGE - 类 中的静态变量org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
 
param(String) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Extracts the param in pathParams first, then falls back to the first matching param in queryParams.
params(String) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Extracts all params in pathParams and queryParams matching the name.
parent - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultSubpartition
The parent partition this subpartition belongs to.
parent - 类 中的变量org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The parent group containing this group.
parent() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
parent() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
parent() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
parent() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
parentFirst(URL[], ClassLoader) - 类 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
parentMetricGroup - 类 中的变量org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
parse(String[]) - 类 中的方法org.apache.flink.runtime.entrypoint.parser.CommandLineParser
 
parseArguments(String[]) - 类 中的静态方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
parseDynamicProperties(CommandLine) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Parse the dynamic properties (passed on the command line).
ParserResultFactory<T> - org.apache.flink.runtime.entrypoint.parser中的接口
Parser result factory used by the CommandLineParser.
PartialInputChannelDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
Partial deployment descriptor for a single input channel instance.
PartialInputChannelDeploymentDescriptor(IntermediateDataSetID, ResultPartitionID, TaskManagerLocation, int) - 类 的构造器org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
PartialOrderPriorityQueue<T> - org.apache.flink.runtime.operators.sort中的类
This class implements a priority-queue, which maintains a partial ordering of its elements such that the least element can always be found in constant time.
PartialOrderPriorityQueue(Comparator<T>, int) - 类 的构造器org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
 
PartitionableListState<S> - org.apache.flink.runtime.state中的类
Implementation of operator list state.
partitionBuffers - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
partitionByKeyGroup() - 类 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner
Partitions the data into key-groups and returns the result via PartitioningResult.
PartitionException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception indicating a problem with the result partitions on the TaskExecutor side.
PartitionException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
partitionId - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
PartitionInfo - org.apache.flink.runtime.executiongraph中的类
Contains information where to find a partition.
PartitionInfo(IntermediateDataSetID, InputChannelDeploymentDescriptor) - 类 的构造器org.apache.flink.runtime.executiongraph.PartitionInfo
 
partitioningDestination - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
The output array for the partitioning.
partitioningSource - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
The input data for the partitioning.
PartitionNotFoundException - org.apache.flink.runtime.io.network.partition中的异常错误
Exception for failed partition requests due to non-existing partitions.
PartitionNotFoundException(ResultPartitionID) - 异常错误 的构造器org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
PartitionProducerDisposedException - org.apache.flink.runtime.jobmanager中的异常错误
Exception returned to a TaskManager on JobManagerMessages.RequestPartitionProducerState if the producer of a partition has been disposed.
PartitionProducerDisposedException(ResultPartitionID) - 异常错误 的构造器org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException
 
PartitionProducerStateChecker - org.apache.flink.runtime.io.network.netty中的接口
Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.
PartitionRequestClient - org.apache.flink.runtime.io.network.netty中的类
Partition request client for remote partition requests.
partitionRequestInitialBackoff() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionRequestMaxBackoff() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionsBeingBuilt - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The partitions that are built by processing the current partition.
path() - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Returns the path of the remote instance.
path() - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Returns the ActorPath of the remote instance.
pathParams() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Returns all params embedded in the request path.
pathToCheckpointId(String) - 类 中的静态方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Converts a path to the checkpoint id.
peek() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
peek() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
peek() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the least element of the PriorityQueue in constant time, but does not remove it from the priority queue.
peek() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
peek() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
peek() - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Retrieves, but does not remove, the element (w.r.t. order) of this set, or returns null if this set is empty.
PendingCheckpoint - org.apache.flink.runtime.checkpoint中的类
A pending checkpoint is a checkpoint that has been started, but has not been acknowledged by all tasks that need to acknowledge it.
PendingCheckpoint(JobID, long, long, Map<ExecutionAttemptID, ExecutionVertex>, CheckpointProperties, CheckpointStorageLocation, Executor) - 类 的构造器org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
PendingCheckpoint.TaskAcknowledgeResult - org.apache.flink.runtime.checkpoint中的枚举
PendingCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
 
PendingCheckpointStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a pending checkpoint that is still in progress.
PendingSlotRequest - org.apache.flink.runtime.resourcemanager.slotmanager中的类
Class representing a pending slot request in the SlotManager.
PendingSlotRequest(SlotRequest) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
PendingSubtaskCheckpointStatistics(int) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics
 
PendingTaskManagerSlot - org.apache.flink.runtime.resourcemanager.slotmanager中的类
Represents a pending task manager slot in the SlotManager.
PendingTaskManagerSlot(ResourceProfile) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
performExecutionVertexRestart(ExecutionVertex, long) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
permanent(Path) - 类 中的静态方法org.apache.flink.runtime.state.SnapshotDirectory
Creates a permanent snapshot directory for the given path, which will not delete the underlying directory in SnapshotDirectory.cleanup() after SnapshotDirectory.completeSnapshotAndGetHandle() was called.
PermanentBlobCache - org.apache.flink.runtime.blob中的类
Provides a cache for permanent BLOB files including a per-job ref-counting and a staged cleanup.
PermanentBlobCache(Configuration, BlobView, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.blob.PermanentBlobCache
Instantiates a new cache for permanent BLOBs which are also available in an HA store.
PermanentBlobKey - org.apache.flink.runtime.blob中的类
BLOB key referencing permanent BLOB files.
PermanentBlobKey() - 类 的构造器org.apache.flink.runtime.blob.PermanentBlobKey
Constructs a new BLOB key.
PermanentBlobService - org.apache.flink.runtime.blob中的接口
A service to retrieve permanent binary large objects (BLOBs).
PersistentMetadataCheckpointStorageLocation - org.apache.flink.runtime.state.memory中的类
A checkpoint storage location for the MemoryStateBackend when it durably persists the metadata in a file system.
PersistentMetadataCheckpointStorageLocation(FileSystem, Path, int) - 类 的构造器org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
Creates a checkpoint storage persists metadata to a file system and stores state in line in state handles with the metadata.
PhysicalSlot - org.apache.flink.runtime.jobmaster.slotpool中的接口
The context of an AllocatedSlot.
PhysicalSlot.Payload - org.apache.flink.runtime.jobmaster.slotpool中的接口
Payload which can be assigned to an AllocatedSlot.
PIPELINED_REGION_RESTART_STRATEGY_NAME - 类 中的静态变量org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartPipelinedRegionStrategy
PipelineErrorHandler - org.apache.flink.runtime.rest.handler中的类
This is the last handler in the pipeline.
PipelineErrorHandler(Logger, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.PipelineErrorHandler
 
PlaceholderStreamStateHandle - org.apache.flink.runtime.state中的类
A placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.
PlaceholderStreamStateHandle() - 类 的构造器org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
poll() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
poll() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
poll() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
poll() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
poll() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
 
poll() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
poll() - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Retrieves and removes the first element (w.r.t. the order) of this set, or returns null if this set is empty.
pollNextBufferOrEvent() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
Poll the BufferOrEvent.
pollNextBufferOrEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
pollNextBufferOrEvent() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
postStop() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricQueryService
 
preferredLocality(ResourceProfile, Collection<TaskManagerLocation>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile and the preferred locations.
prepare() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
prepare() - 接口 中的方法org.apache.flink.runtime.operators.Driver
This method is called before the user code is opened.
prepare() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
prepare() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
prepareLeadershipAsync() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
This method can be overridden to add a (non-blocking) initialization routine to the ResourceManager that will be called when leadership is granted but before leadership is confirmed.
prepareNextPartition() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
prepareNextPartition() - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
prepareProbePhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
preStart() - 类 中的方法org.apache.flink.runtime.akka.QuarantineMonitor
 
PreviousAllocationSlotSelectionStrategy - org.apache.flink.runtime.jobmaster.slotpool中的枚举
This class implements a SlotSelectionStrategy that is based on previous allocations and falls back to using location preference hints if there is no previous allocation.
previousSchemaSerializer() - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
Gets the serializer that recognizes the previous serialization schema of the state.
PrimaryAndSecondaryStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream) - 类 的构造器org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
 
PrimaryStreamOnly(CheckpointStreamFactory.CheckpointStateOutputStream) - 类 的构造器org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
 
printHelp(String) - 类 中的方法org.apache.flink.runtime.entrypoint.parser.CommandLineParser
 
priorAllocation(ResourceProfile, Collection<AllocationID>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile and the prior allocations.
prioritizedOperatorState(OperatorID) - 接口 中的方法org.apache.flink.runtime.state.TaskStateManager
Returns means to restore previously reported state of an operator running in the owning task.
prioritizedOperatorState(OperatorID) - 类 中的方法org.apache.flink.runtime.state.TaskStateManagerImpl
 
PrioritizedOperatorSubtaskState - org.apache.flink.runtime.checkpoint中的类
This class is a wrapper over multiple alternative OperatorSubtaskState that are (partial) substitutes for each other and imposes a priority ordering over all alternatives for the different states which define an order in which the operator should attempt to restore the state from them.
PrioritizedOperatorSubtaskState.Builder - org.apache.flink.runtime.checkpoint中的类
 
PriorityComparable<T> - org.apache.flink.runtime.state中的接口
Interface for objects that can be compared by priority.
PriorityComparator<T> - org.apache.flink.runtime.state中的接口
This interface works similar to Comparable and is used to prioritize between two objects.
PriorityQueueSetFactory - org.apache.flink.runtime.state中的接口
Factory for KeyGroupedInternalPriorityQueue instances.
probeIterator - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
Iterator over the elements from the probe side.
probeSideBuffer - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideChannel - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideRecordCounter - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to serialize the probe side data types.
probeSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
probeSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
probeSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
probeSideSerializer - 类 中的变量org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
probeTypeComparator - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
process(K, S) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateFunction
The actual method to be applied on each of the states.
processExitCode() - 枚举 中的方法org.apache.flink.runtime.clusterframework.ApplicationStatus
Gets the process exit code associated with this status
ProcessingModeDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer
 
ProcessingModeSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
 
processProbeIter() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
ProcessReaper - org.apache.flink.runtime.process中的类
Utility actors that monitors other actors and kills the JVM upon actor termination.
ProcessReaper(ActorRef, Logger, int) - 类 的构造器org.apache.flink.runtime.process.ProcessReaper
 
ProcessShutDownThread - org.apache.flink.runtime.util中的类
JVM shut down thread awaiting actor system shut down for a certain amount of time before exiting the JVM.
ProcessShutDownThread(Logger, ActorSystem, Duration) - 类 的构造器org.apache.flink.runtime.util.ProcessShutDownThread
Creates a shut down thread.
processUnmatchedBuildIter() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
 
ProducerFailedException - org.apache.flink.runtime.io.network.partition中的异常错误
Network-stack level Exception to notify remote receiver about a failed partition producer.
ProducerFailedException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.network.partition.ProducerFailedException
The cause of the producer failure.
ProxyMetricGroup<P extends org.apache.flink.metrics.MetricGroup> - org.apache.flink.runtime.metrics.groups中的类
Metric group which forwards all registration calls to its parent metric group.
ProxyMetricGroup(P) - 类 的构造器org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
prune() - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Clears the buffer and checks to decrease the size of intermediate data serialization buffer after finishing the whole serialization process including RecordSerializer.serializeRecord(IOReadableWritable) and RecordSerializer.copyToBufferBuilder(BufferBuilder).
prune() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
pruneMatchingCheckpoints(LongPredicate) - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
pruneMatchingCheckpoints(LongPredicate) - 接口 中的方法org.apache.flink.runtime.state.TaskLocalStateStore
Remove all checkpoints from the store that match the given predicate.
pruneMatchingCheckpoints(LongPredicate) - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
publish(TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
publish(TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.api.TaskEventHandler
Publishes the task event to all subscribed event listeners.
publish(ResultPartitionID, TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
Publishes the event to the registered EventListener instances.
pushDownPages() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
put(File, JobID, BlobKey) - 接口 中的方法org.apache.flink.runtime.blob.BlobStore
Copies the local file to the blob store.
put(File, JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.FileSystemBlobStore
 
put(File, JobID, BlobKey) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobStore
 
put(ArchivedExecutionGraph) - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Store the given ArchivedExecutionGraph in the store.
put(ArchivedExecutionGraph) - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
put(ArchivedExecutionGraph) - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
put(A, B, V) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
put(T) - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds a buffer to a PriorityQueue in log(size) time.
put(K, int, N, S) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
put(K, int, N, S) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
put(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Maps the composite of active key and given namespace to the specified state.
put(K, int, N, S) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
put(K, V) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
put(JobID, JobManagerConnection) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerTable
 
putAll(Map<K, V>) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
putAndGetOld(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
putAndGetOld(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
putAndGetOld(N, S) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Maps the composite of active key and given namespace to the specified state.
putJobGraph(SubmittedJobGraph) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
putJobGraph(SubmittedJobGraph) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
putJobGraph(SubmittedJobGraph) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Adds the SubmittedJobGraph instance.
putJobGraph(SubmittedJobGraph) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
putPermanent(JobID, byte[]) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putPermanent(JobID, InputStream) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putPermanent(JobID, byte[]) - 接口 中的方法org.apache.flink.runtime.blob.BlobWriter
Uploads the data of the given byte array for the given job to the BLOB server and makes it a permanent BLOB.
putPermanent(JobID, InputStream) - 接口 中的方法org.apache.flink.runtime.blob.BlobWriter
Uploads the data from the given input stream for the given job to the BLOB server and makes it a permanent BLOB.
putPermanent(JobID, byte[]) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobWriter
 
putPermanent(JobID, InputStream) - 类 中的方法org.apache.flink.runtime.blob.VoidBlobWriter
 
putState(int, OperatorSubtaskState) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
putState(int, SubtaskState) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
putSubtaskStateByOperatorID(OperatorID, OperatorSubtaskState) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
Maps the given operator id to the given subtask state.
putTransient(byte[]) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putTransient(JobID, byte[]) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putTransient(InputStream) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putTransient(JobID, InputStream) - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
putTransient(byte[]) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(JobID, byte[]) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(InputStream) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(JobID, InputStream) - 类 中的方法org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(byte[]) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Uploads the (job-unrelated) data of the given byte array to the BLOB server.
putTransient(JobID, byte[]) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Uploads the data of the given byte array for the given job to the BLOB server.
putTransient(InputStream) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Uploads the (job-unrelated) data from the given input stream to the BLOB server.
putTransient(JobID, InputStream) - 接口 中的方法org.apache.flink.runtime.blob.TransientBlobService
Uploads the data from the given input stream for the given job to the BLOB server.
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Enters all variables specific to this AbstractMetricGroup and their associated values into the map.
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
 
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
putVariables(Map<String, String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 

Q

QuarantineHandler - org.apache.flink.runtime.akka中的接口
Callback interface for the QuarantineMonitor which is called in case the actor system has been quarantined or quarantined another system.
QuarantineMonitor - org.apache.flink.runtime.akka中的类
The quarantine monitor subscribes to the event bus of the actor system in which it was started.
QuarantineMonitor(QuarantineHandler, Logger) - 类 的构造器org.apache.flink.runtime.akka.QuarantineMonitor
 
QueryableStateConfiguration - org.apache.flink.runtime.taskexecutor中的类
Simple configuration object for the parameters for the server-side of queryable state.
QueryableStateConfiguration(Iterator<Integer>, Iterator<Integer>, int, int, int, int) - 类 的构造器org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
 
QueryableStateUtils - org.apache.flink.runtime.query中的类
Utility class to initialize entities used in queryable state.
QueryableStateUtils() - 类 的构造器org.apache.flink.runtime.query.QueryableStateUtils
 
queryMetrics(Time) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
queryMetrics(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
 
queryParam(String) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Extracts the first matching param in queryParams.
queryParams() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Returns all params in the query part of the request URI.
QueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for scope related information as required by the MetricQueryService.
QueryScopeInfo.JobManagerQueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for the job manager scope.
QueryScopeInfo.JobQueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for the job scope.
QueryScopeInfo.OperatorQueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for the operator scope.
QueryScopeInfo.TaskManagerQueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for the task manager scope.
QueryScopeInfo.TaskQueryScopeInfo - org.apache.flink.runtime.metrics.dump中的类
Container for the task scope.
queryServiceScopeInfo - 类 中的变量org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The metrics query service scope represented by this group, lazily computed.
queue - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
The array that represents the heap-organized priority queue.
queues - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
The queue of empty buffer that can be used for reading;
queueStatus() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
queueStatus() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
queueStatus() - 接口 中的方法org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
Returns the status of the resource creation.
QueueStatus - org.apache.flink.runtime.rest.messages.queue中的类
Response type for temporary queue resources, i.e., resources that are asynchronously created.
QueueStatus(QueueStatus.Id) - 类 的构造器org.apache.flink.runtime.rest.messages.queue.QueueStatus
 
QueueStatus.Id - org.apache.flink.runtime.rest.messages.queue中的枚举
Defines queue statuses.
QueuingCallback<T> - org.apache.flink.runtime.io.disk.iomanager中的类
A RequestDoneCallback that adds the memory segments to a blocking queue.
QueuingCallback(LinkedBlockingQueue<T>) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
QuickSort - org.apache.flink.runtime.operators.sort中的类
 
QuickSort() - 类 的构造器org.apache.flink.runtime.operators.sort.QuickSort
 

R

RandomAccessInputView - org.apache.flink.runtime.io.disk中的类
 
RandomAccessInputView(ArrayList<MemorySegment>, int) - 类 的构造器org.apache.flink.runtime.io.disk.RandomAccessInputView
 
RandomAccessInputView(ArrayList<MemorySegment>, int, int) - 类 的构造器org.apache.flink.runtime.io.disk.RandomAccessInputView
 
RandomAccessOutputView - org.apache.flink.runtime.io.disk中的类
 
RandomAccessOutputView(MemorySegment[], int) - 类 的构造器org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
RandomAccessOutputView(MemorySegment[], int, int) - 类 的构造器org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
randomEmit(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
This is used to send LatencyMarks to a random target channel.
RangeBoundaryBuilder<T> - org.apache.flink.runtime.operators.udf中的类
Build RangeBoundaries with input records.
RangeBoundaryBuilder(TypeComparatorFactory<T>, int) - 类 的构造器org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
 
rate - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
RawJsonDeserializer - org.apache.flink.runtime.rest.messages.json中的类
Json deserializer which deserializes raw json.
RawJsonDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
 
read() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
read() - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.iterative.event.TerminationEvent
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
read(byte[]) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
read(byte[], int, int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.plugable.SerializationDelegate
 
read() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[]) - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
read(DataInputView) - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
read() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
read(byte[]) - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
read(byte[], int, int) - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
readableBytes() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns the number of readable bytes (same as Buffer.getSize() - Buffer.getReaderIndex()).
readAndSetBroadcastInput(int, String, DistributedRuntimeUDFContext, int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
readBlock(MemorySegment) - 类 中的方法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) - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readBufferFromFileChannel(Buffer) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileChannelReader
Reads data from the object's file channel into the given buffer.
readByte() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readBytes(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
readChar() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readDouble() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readElement(DataInputView) - 接口 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner.ElementReaderFunction
 
reader - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
Reader<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.reader中的接口
A record-oriented reader for immutable record types.
ReaderBase - org.apache.flink.runtime.io.network.api.reader中的接口
The basic API for every reader.
ReaderIterator<T> - 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>) - 类 的构造器org.apache.flink.runtime.operators.util.ReaderIterator
Creates a new iterator, wrapping the given reader.
readFloat() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[]) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[], int, int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
ReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, E, AbstractInvokable, long) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
Creates a new reading thread.
readInt() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readInto(Buffer) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
readInto(Buffer) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
readInto(Buffer) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
readLine() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readLong() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readMappingsInKeyGroup(DataInputView, int) - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotKeyGroupReader
Read the data for the specified key-group from the input.
readOnlySlice() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns a read-only slice of this buffer's readable bytes, i.e. between Buffer.getReaderIndex() and Buffer.getSize().
readOnlySlice(int, int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Returns a read-only slice of this buffer.
readOnlySlice() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
readOnlySlice(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
readOnlySlice() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
readOnlySlice(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
ReadOnlySlicedNetworkBuffer - 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 - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
readRecordAt(long, T) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
readRecordAt(long) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
readResolve() - 类 中的方法org.apache.flink.runtime.messages.Acknowledge
Read resolve to preserve the singleton object property.
readResolve() - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
readResolve() preserves the singleton property of the default value.
readShort() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readStateMetaInfoSnapshot(DataInputView, ClassLoader) - 类 中的方法org.apache.flink.runtime.state.metainfo.LegacyStateMetaInfoReaders.OperatorBackendStateMetaInfoReaderV1
 
readStateMetaInfoSnapshot(DataInputView, ClassLoader) - 接口 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoReader
Reads a snapshot from the given input view.
readUnsignedByte() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readUnsignedShort() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readUTF() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
readWriteLock - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Lock guarding concurrent file accesses.
receiveAcknowledgeMessage(AcknowledgeCheckpoint) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives an AcknowledgeCheckpoint message and returns whether the message was associated with a pending checkpoint.
receiveDeclineMessage(DeclineCheckpoint) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives a DeclineCheckpoint message for a pending checkpoint.
receiveHeartbeat(ResourceID, I) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
receiveHeartbeat(ResourceID, I) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatTarget
Sends a heartbeat response to the target.
reconnect(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Triggers reconnection to the last known leader of the given job.
ReconnectResourceManager - org.apache.flink.runtime.clusterframework.messages中的类
This message signals that the ResourceManager should reconnect to the JobManager.
ReconnectResourceManager(ActorRef, long) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
RecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.serialization中的接口
Interface for turning sequences of memory segments into records.
RecordDeserializer.DeserializationResult - org.apache.flink.runtime.io.network.api.serialization中的枚举
Status of the deserialization result.
RecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.reader中的类
Record oriented reader for immutable types.
RecordReader(InputGate, Class<T>, String[]) - 类 的构造器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> - org.apache.flink.runtime.io.network.api.serialization中的接口
Interface for turning records into sequences of memory segments.
RecordSerializer.SerializationResult - org.apache.flink.runtime.io.network.api.serialization中的枚举
Status of the serialization result.
recordSize() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
recordSize() - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the size of each record, the number of bytes separating the head of successive records.
recordSize() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
recordsPerSegment() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
recordsPerSegment() - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the number of elements in each memory segment.
recordsPerSegment() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
RecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
A record-oriented runtime result writer.
RecordWriter(ResultPartitionWriter) - 类 的构造器org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
RecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - 类 的构造器org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
recover() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Recover available CompletedCheckpoint instances.
recover() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
recover() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Gets the latest checkpoint from ZooKeeper and removes all others.
recoverJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
recoverJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
recoverJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Returns the SubmittedJobGraph with the given JobID or null if no job was registered.
recoverJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
recursionLevel - 类 中的变量org.apache.flink.runtime.operators.hash.HashPartition
 
recycle(MemorySegment) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferRecycler
Recycles the MemorySegment to its original BufferPool instance.
recycle(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
Frees the given memory segment.
recycle(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
recycle(MemorySegment) - 类 中的方法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() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Releases this buffer once, i.e. reduces the reference count and recycles the buffer if the reference count reaches 0.
recycleBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
recycleBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
recycleMemorySegments(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
RedirectingSslHandler - org.apache.flink.runtime.net中的类
SSL handler which automatically redirects Non-SSL requests to SSL address.
RedirectingSslHandler(String, CompletableFuture<String>, SSLHandlerFactory) - 类 的构造器org.apache.flink.runtime.net.RedirectingSslHandler
 
ReduceCombineDriver<T> - org.apache.flink.runtime.operators中的类
Combine operator for Reduce functions, standalone (not chained).
ReduceCombineDriver() - 类 的构造器org.apache.flink.runtime.operators.ReduceCombineDriver
 
ReduceDriver<T> - org.apache.flink.runtime.operators中的类
Reduce driver which is executed by a Task Manager.
ReduceDriver() - 类 的构造器org.apache.flink.runtime.operators.ReduceDriver
 
ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
 
refCnt() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
refresh() - 类 中的方法org.apache.flink.runtime.security.DynamicConfiguration
 
register(Metric, String, AbstractMetricGroup) - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Registers a new Metric with this registry.
register(Metric, String, AbstractMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
register(Metric, String, AbstractMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
register(Logger) - 类 中的静态方法org.apache.flink.runtime.util.SignalHandler
Register some signal handlers.
registerAll(Iterable<? extends CompositeStateHandle>) - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
Register given shared states in the registry.
registerAllRequestsProcessedListener(NotificationListener) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
registerAllRequestsProcessedListener(NotificationListener) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Registers a listener to be notified when all outstanding requests have been processed.
registerAllRequestsProcessedListener(NotificationListener) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
Registers a listener, which is notified after all outstanding requests have been processed.
registerBufferPool(BufferPool) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Registers a buffer pool with this result partition.
registerChannelToBeRemovedAtShudown(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel to the list of channels that are to be removed at shutdown.
registerConsumer() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
RegisteredBroadcastStateBackendMetaInfo<K,V> - org.apache.flink.runtime.state中的类
 
RegisteredBroadcastStateBackendMetaInfo(String, OperatorStateHandle.Mode, TypeSerializer<K>, TypeSerializer<V>) - 类 的构造器org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
RegisteredBroadcastStateBackendMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - 类 的构造器org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
RegisteredBroadcastStateBackendMetaInfo(StateMetaInfoSnapshot) - 类 的构造器org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
RegisteredKeyValueStateBackendMetaInfo<N,S> - 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>) - 类 的构造器org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
RegisteredKeyValueStateBackendMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - 类 的构造器org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
RegisteredKeyValueStateBackendMetaInfo(StateMetaInfoSnapshot) - 类 的构造器org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
RegisteredOperatorStateBackendMetaInfo<S> - org.apache.flink.runtime.state中的类
Compound meta information for a registered state in an operator state backend.
RegisteredOperatorStateBackendMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - 类 的构造器org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
RegisteredOperatorStateBackendMetaInfo(StateMetaInfoSnapshot) - 类 的构造器org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
registeredPartitions - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
RegisteredPriorityQueueStateBackendMetaInfo<T> - org.apache.flink.runtime.state中的类
Meta information about a priority queue state in a backend.
RegisteredPriorityQueueStateBackendMetaInfo(String, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
RegisteredPriorityQueueStateBackendMetaInfo(StateMetaInfoSnapshot) - 类 的构造器org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
RegisteredRpcConnection<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - 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) - 类 的构造器org.apache.flink.runtime.registration.RegisteredRpcConnection
 
RegisteredStateMetaInfoBase - org.apache.flink.runtime.state中的类
Base class for all registered state in state backends.
RegisteredStateMetaInfoBase(String) - 类 的构造器org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
 
registerExecutionListener(ExecutionStatusListener) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
RegisterInfoMessageListener - org.apache.flink.runtime.clusterframework.messages中的类
This message signals to the resource master to register the sender as an info message listener.
registerInfoMessageListener(String) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Registers an info message listener.
registerInfoMessageListener(String) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Registers an infoMessage listener
RegisterInfoMessageListenerSuccessful - org.apache.flink.runtime.clusterframework.messages中的类
This message signals to the application client that the registration was successful.
registerJob(JobID) - 类 中的方法org.apache.flink.runtime.blob.PermanentBlobCache
Registers use of job-related BLOBs.
registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job with its required jar files and classpaths.
registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a JobMaster at the resource manager.
registerJobStatusListener(JobStatusListener) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
State backend will call KeyedStateBackend.KeySelectionListener.keySelected(K) when key context is switched if supported.
registerKvState(KeyGroupRange, KvStateID, InetSocketAddress) - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
Registers a KvState instance for the given key group index.
registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?, ?, ?>) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Registers the KvState instance and returns the assigned ID.
registerKvState(KeyGroupRange, String, InternalKvState<?, ?, ?>) - 类 中的方法org.apache.flink.runtime.query.TaskKvStateRegistry
Registers the KvState instance at the KvStateRegistry.
registerListener(InputGateListener) - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
registerListener(InputGateListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
registerListener(InputGateListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
registerListener(JobID, KvStateRegistryListener) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Registers a listener with the registry.
registerMetrics(MetricGroup) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Tells the FailoverStrategy to register its metrics.
registerMetrics(MetricGroup) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
registerNewSerializerForRestoredState(TypeSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
For restored state, register a new serializer that potentially has a new serialization schema.
registerOpenChannelToBeRemovedAtShudown(FileIOChannel) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel reader/writer to the list of channels that are to be removed at shutdown.
registerPartition(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
Registers the given partition for incoming task events allowing calls to TaskEventDispatcher.subscribeToEvent(ResultPartitionID, EventListener, Class).
registerQueueLengthMetrics(MetricGroup, SingleInputGate) - 类 中的静态方法org.apache.flink.runtime.io.network.partition.consumer.InputGateMetrics
 
registerQueueLengthMetrics(MetricGroup, ResultPartition) - 类 中的静态方法org.apache.flink.runtime.io.network.partition.ResultPartitionMetrics
 
registerReference(SharedStateRegistryKey, StreamStateHandle) - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
Register a reference to the given shared state in the registry.
RegisterResourceManager - org.apache.flink.runtime.clusterframework.messages中的类
This message signals that the resource manager wants to register at the JobManager leader.
RegisterResourceManager(ActorRef) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
RegisterResourceManagerSuccessful - org.apache.flink.runtime.clusterframework.messages中的类
Message that informs the resource manager that the JobManager accepted its registration.
RegisterResourceManagerSuccessful(ActorRef, Collection<ResourceID>) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
Creates a new message with a list of existing known TaskManagers.
registerResultPartition(ResultPartition) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
registerSharedStates(SharedStateRegistry) - 接口 中的方法org.apache.flink.runtime.state.CompositeStateHandle
Register both newly created and already referenced shared states in the given SharedStateRegistry.
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
registerSharedStates(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
registerSharedStatesAfterRestored(SharedStateRegistry) - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
Register all shared states in the given registry.
registerSlotRequest(SlotRequest) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Requests a slot with the respective resource profile.
registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job task execution with its required jar files and classpaths.
registerTask(Task) - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a TaskExecutor at the resource manager.
registerTaskManager(TaskManagerGateway, TaskManagerLocation, HardwareDescription, int) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
Registers a task manager.
registerTaskManager(String, TaskManagerLocation, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
registerTaskManager(String, TaskManagerLocation, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Registers the task manager at the job manager.
registerTaskManager(ResourceID) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Registers a TaskExecutor with the given ResourceID at SlotPool.
registerTaskManager(ResourceID) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Registers a new task manager at the slot manager.
registerTimeout(K, long, TimeUnit) - 类 中的方法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> - org.apache.flink.runtime.registration中的接口
Classes which want to be notified about the registration result by the RegisteredRpcConnection have to implement this interface.
RegistrationResponse - org.apache.flink.runtime.registration中的类
Base class for responses given to registration attempts from RetryingRegistration.
RegistrationResponse() - 类 的构造器org.apache.flink.runtime.registration.RegistrationResponse
 
RegistrationResponse.Decline - org.apache.flink.runtime.registration中的类
A rejected (declined) registration.
RegistrationResponse.Success - org.apache.flink.runtime.registration中的类
Base class for a successful registration.
RegistrationTimeoutException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception which indicates that the TaskExecutor could not register at the master in time.
RegistrationTimeoutException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
 
RegistrationTimeoutException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
 
RegistrationTimeoutException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
 
registry - 类 中的变量org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The registry that this metrics group belongs to.
RegularToMutableObjectIterator<T> - org.apache.flink.runtime.util中的类
 
RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
relativeTimeMillis() - 类 中的方法org.apache.flink.runtime.util.clock.Clock
 
relativeTimeMillis() - 类 中的方法org.apache.flink.runtime.util.clock.SystemClock
 
relativeTimeNanos() - 类 中的方法org.apache.flink.runtime.util.clock.Clock
 
relativeTimeNanos() - 类 中的方法org.apache.flink.runtime.util.clock.SystemClock
 
release() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
release(Throwable) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Releases the result partition.
release() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
release(Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot.Payload
Releases the payload
release(Throwable) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
 
release(Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
 
release(Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
Release the task slot.
release(MemorySegment) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Tries to release the memory for the specified segment.
release(Collection<MemorySegment>) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Tries to release many memory segments together.
release() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
release(int) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
release() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
release() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
 
release() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshot
Release the snapshot.
release(String) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases the lock from the node under the given ZooKeeper path.
releaseAll(Object) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Releases all memory segments for the given owner.
releaseAll() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases all lock nodes of this ZooKeeperStateHandleStore.
releaseAllReferencesFromTask(BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseAllResources() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
releaseAllResources() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
releaseAllResources() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
releaseAndTryRemove(String) - 类 中的方法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() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
releaseJob(JobID) - 类 中的方法org.apache.flink.runtime.blob.PermanentBlobCache
Unregisters use of job-related BLOBs and allow them to be released.
releaseJob(JobID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.filecache.FileCache
 
releaseJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
releaseJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
releaseJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Releases the locks on the specified JobGraph.
releaseJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
releaseLocalStateForAllocationId(AllocationID) - 类 中的方法org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
releaseMemory(int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPoolOwner
 
releaseMemory(int) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
Releases buffers held by this result partition.
releasePartitionsProducedBy(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releasePartitionsProducedBy(ExecutionAttemptID, Throwable) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releaseReference(String, int, BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseReference(BroadcastVariableKey, BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseResource(InstanceID, Exception) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
releaseResource(InstanceID, Exception) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Releases the resource with the given instance id.
releaseSlot(Throwable) - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
releaseSlot(Throwable) - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
releaseSlot(Throwable) - 类 中的方法org.apache.flink.runtime.instance.Slot
This method cancels and releases the slot and all its sub-slots.
releaseSlot() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
已过时。
Added because extended the actual releaseSlot method with cause parameter.
releaseSlot(Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Releases this slot.
releaseSlot(SlotRequestId, Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
Releases the slot with the given SlotRequestId.
releaseSlot(Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
releaseSlot(SlotRequestId, Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
releaseTable() - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
releaseTaskManager(ResourceID, Exception) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Releases a TaskExecutor with the given ResourceID from the SlotPool.
releaseTaskManager(ResourceID, Exception) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
Unregister TaskManager from this pool, all the related slots will be released and tasks be canceled.
remainingCapacity() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the remaining capacity of the backing array.
RemoteFencedMessage<F extends Serializable,P extends Serializable> - org.apache.flink.runtime.rpc.messages中的类
Remote FencedMessage implementation.
RemoteFencedMessage(F, P) - 类 的构造器org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
RemoteHandshakeMessage - org.apache.flink.runtime.rpc.messages中的类
Handshake message between rpc endpoints.
RemoteHandshakeMessage(Class<?>, int) - 类 的构造器org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
RemoteInputChannel - org.apache.flink.runtime.io.network.partition.consumer中的类
An input channel, which requests a remote partition queue.
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, TaskIOMetricGroup) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, int, int, TaskIOMetricGroup) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteRpcInvocation - 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[]) - 类 的构造器org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
RemoteTransportException - org.apache.flink.runtime.io.network.netty.exception中的异常错误
 
RemoteTransportException(String, SocketAddress) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
 
RemoteTransportException(String, SocketAddress, Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
 
remove(Object) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
remove(String) - 类 中的方法org.apache.flink.runtime.iterative.concurrent.Broker
Blocking retrieval and removal of the object to share.
remove(Object) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
remove() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
remove() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
remove() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
remove() - 类 中的方法org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
remove(T) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
remove(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
remove(T) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
remove(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
remove(N) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Removes the mapping for the composite of active key and given namespace.
remove(K) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
remove(StateEntry<K, N, V>) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
 
remove(T) - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Removes the given element from the set, if is contained in the set.
remove(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerTable
 
remove(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Remove the task identified by the given execution attempt id.
remove() - 类 中的方法org.apache.flink.runtime.util.EmptyIterator
remove() - 类 中的方法org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
remove() - 类 中的方法org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
remove() - 类 中的方法org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
remove() - 类 中的方法org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
remove() - 类 中的方法org.apache.flink.runtime.util.SingleElementIterator
 
removeAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
removeAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
removeAndGetOld(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
removeAndGetOld(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
removeAndGetOld(N) - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
removeInputChannel(RemoteInputChannel) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkClientHandler
 
removeInstanceListener(InstanceListener) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
removeInternal(int) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
Implements how to remove the element at the given index from the queue.
removeInternal(int) - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueue
 
removeJob(JobID) - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
removeJob(JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Remove the given job from being monitored by the service.
removeJob(JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
removeJob(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Remove the given job from being monitored by the job leader service.
removeJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
removeJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
removeJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Removes the SubmittedJobGraph with the given JobID if it exists.
removeJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
removeKeyA(A) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
removeKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
removeLast() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
removeLong(int) - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
removePathPattern(String) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Removes the route specified by the path pattern.
RemoveRangeIndex<T> - org.apache.flink.runtime.operators.udf中的类
 
RemoveRangeIndex() - 类 的构造器org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
RemoveResource - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the ResourceManager by the JobManager to instruct to remove a resource.
RemoveResource(ResourceID) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.RemoveResource
Constructor for a shutdown of a registered resource.
removeSlotListener() - 类 中的方法org.apache.flink.runtime.instance.Instance
Removes the listener that receives notifications for slot availability.
removeTask(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Remove the task with the given execution attempt id from its task slot.
removeTaskMetricGroup(AbstractID) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
removeVertexFromGroup(JobVertexID) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
reopen(Iterator<T>) - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
ReOpenableHashPartition<BT,PT> - org.apache.flink.runtime.operators.hash中的类
 
ReOpenableMutableHashTable<BT,PT> - org.apache.flink.runtime.operators.hash中的类
 
ReOpenableMutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - 类 的构造器org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
reopenProbe(MutableObjectIterator<V2>) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<V1>) - 类 中的方法org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<PT>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
reopenProbe(MutableObjectIterator<V2>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<V1>) - 类 中的方法org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
Set new input for probe side
repartitionState(List<List<OperatorStateHandle>>, int, int) - 接口 中的方法org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
 
repartitionState(List<List<OperatorStateHandle>>, int, int) - 类 中的方法org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
replace(String, int, T) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Replaces a state handle in ZooKeeper and discards the old state handle.
reportAllElementKeyGroups() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot.StateTableKeyGroupPartitioner
 
reportAllElementKeyGroups() - 类 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner
This method iterates over the input data and reports the key-group for each element.
reporterIndex - 类 中的变量org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
reportHeartBeat() - 类 中的方法org.apache.flink.runtime.instance.Instance
Updates the time of last received heart beat to the current system time.
reportHeartBeat(InstanceID) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
reportKeyGroupOfElementAtIndex(int, int) - 类 中的方法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) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatListener
Callback which is called whenever a heartbeat with an associated payload is received.
reportSlotStatus(InstanceID, SlotReport) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Reports the current slot allocations for a task manager identified by the given instance id.
reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.state.TaskStateManager
Report the state snapshots for the operator instances running in the owning task.
reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.state.TaskStateManagerImpl
 
RequestBody - org.apache.flink.runtime.rest.messages中的接口
Marker interface for all requests of the REST API.
requestBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a Buffer instance from the buffer provider, if one is available.
requestBuffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Requests buffer from input channel directly for receiving network data.
requestBufferBlocking() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a Buffer instance from the buffer provider.
requestBufferBuilderBlocking() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a BufferBuilder instance from the buffer provider.
requestClusterOverview(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestClusterOverview() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
requestClusterOverview(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the cluster status overview.
RequestDoneCallback<T> - org.apache.flink.runtime.io.disk.iomanager中的接口
Callback to be executed on completion of an asynchronous I/O request.
requestFailed(T, IOException) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
requestFailed(T, IOException) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
 
requestFileUpload(ResourceManagerGateway, ResourceID) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
requestFileUpload(ResourceManagerGateway, ResourceID) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
 
requestFileUpload(ResourceManagerGateway, ResourceID) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
 
requestFileUpload(FileType, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestFileUpload(FileType, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Requests the file upload of the specified type to the cluster's BlobServer.
requestHeartbeat(ResourceID, I) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
requestHeartbeat(ResourceID, I) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatTarget
Requests a heartbeat from the target.
requestJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherGateway
Requests the ArchivedExecutionGraph for the given jobId.
requestJob(Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestJob(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the ArchivedExecutionGraph of the executed job.
requestJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the ArchivedExecutionGraph for the given jobId.
requestJobDetails(Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestJobDetails(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Request the details of the executed job.
RequestJobDetails - 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) - 类 的构造器org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
requestJobResult(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJobResult(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
 
requestJobResult(JobID) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
requestJobResult(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the JobResult of a job specified by the given jobId.
RequestJobsOverview - org.apache.flink.runtime.messages.webmonitor中的类
This message requests an overview of how many jobs are in which status.
requestJobStatus(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJobStatus(Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestJobStatus(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the current job status.
requestJobStatus(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Request the JobStatus of the given job.
RequestJobsWithIDsOverview - org.apache.flink.runtime.messages.webmonitor中的类
This message requests an overview of how many jobs are in which status.
requestKvStateLocation(JobID, String) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestKvStateLocation(JobID, String) - 接口 中的方法org.apache.flink.runtime.jobmaster.KvStateLocationOracle
Requests a KvStateLocation for the specified InternalKvState registration name.
requestKvStateLocation(JobID, String) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
 
requestMemorySegment() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
requestMemorySegments(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
requestMetricQueryServiceAddress(Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestMetricQueryServiceAddress(Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Returns the fully qualified address of Metric Query Service on the TaskManager.
requestMetricQueryServicePaths(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestMetricQueryServicePaths(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the paths for the MetricQueryService to query.
requestMultipleJobDetails(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestMultipleJobDetails(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests job details currently being executed on the Flink cluster.
requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Request the allocation of a new slot from the resource manager.
requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the next input split for the ExecutionJobVertex.
requestOperatorBackPressureStats(JobID, JobVertexID) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestOperatorBackPressureStats(JobVertexID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestOperatorBackPressureStats(JobVertexID) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the statistics on operator back pressure.
requestOperatorBackPressureStats(JobID, JobVertexID) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the statistics on operator back pressure.
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.io.network.netty.PartitionProducerStateChecker
Requests the execution state of the execution producing a result partition.
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
 
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
requestPartitions() - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
requestPartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
requestPartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
requestPartitionState(IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
requestPartitionState(IntermediateDataSetID, ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the current state of the partition.
requestQueue - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
A request queue for submitting asynchronous requests to the corresponding IO worker thread.
RequestQueue<E> - org.apache.flink.runtime.io.disk.iomanager中的类
A LinkedBlockingQueue that is extended with closing methods.
RequestQueue() - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.RequestQueue
 
requestResourceOverview(Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestResourceOverview(Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests the resource overview.
requestSlot(JobMasterId, SlotRequest, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestSlot(JobMasterId, SlotRequest, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests a slot from the resource manager.
requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Requests a slot from the TaskManager.
requestsNotReturned - 类 中的变量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) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Request a stack trace sample from the task of this execution.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request a stack trace sample from the given task.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
 
RequestStatusOverview - 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) - 类 中的方法org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Requests a remote intermediate result partition queue.
requestSubpartition(int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Requests a remote subpartition.
requestSubpartitionView(ResultPartitionProvider, ResultPartitionID, int) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
requestSuccessful(T) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
requestSuccessful(T) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
 
requestTaskManagerFileUpload(ResourceID, FileType, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerFileUpload(ResourceID, FileType, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Request the file upload from the given TaskExecutor to the cluster's BlobServer.
requestTaskManagerInfo(Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerInfo(ResourceID, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerInfo(Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests information about the registered TaskExecutor.
requestTaskManagerInfo(ResourceID, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests information about the given TaskExecutor.
requestTaskManagerMetricQueryServicePaths(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
requestTaskManagerMetricQueryServicePaths(Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerMetricQueryServicePaths(Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests the paths for the TaskManager's MetricQueryService to query.
requestTaskManagerMetricQueryServicePaths(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the paths for the TaskManager's MetricQueryService to query.
requestTermination() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
requestTermination() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
requestTermination() - 接口 中的方法org.apache.flink.runtime.iterative.task.Terminable
 
requiresComparator() - 枚举 中的方法org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
requiresComparator() - 枚举 中的方法org.apache.flink.runtime.operators.util.LocalStrategy
 
requiresExternalizedCheckpoints() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
This method returns whether the completed checkpoint store requires checkpoints to be externalized.
requiresExternalizedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
requiresExternalizedCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
RequiresLeaderSessionID - org.apache.flink.runtime.messages中的接口
Marks messages to be sent wrapped in a JobManagerMessages.LeaderSessionMessage
requiresLegacySynchronousTimerSnapshots() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
requiresPreviousExecutionGraphAllocations() - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.Scheduler
Returns true, iff the scheduling strategy of the scheduler requires to know about previous allocations.
requiresPreviousExecutionGraphAllocations() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
rescaleJob(JobID, int, RescalingBehaviour, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
rescaleJob(int, RescalingBehaviour, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
rescaleJob(int, RescalingBehaviour, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers rescaling of the executed job.
rescaleJob(JobID, int, RescalingBehaviour, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Trigger rescaling of the given job.
rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers rescaling of the given set of operators.
RescalingBehaviour - org.apache.flink.runtime.jobmaster中的枚举
Definition of the rescaling behaviour.
RescalingHandlers - org.apache.flink.runtime.rest.handler.job.rescaling中的类
Rest handler to trigger and poll the rescaling of a running job.
RescalingHandlers() - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers
 
RescalingHandlers.RescalingStatusHandler - org.apache.flink.runtime.rest.handler.job.rescaling中的类
Handler which reports the status of the rescaling operation.
RescalingHandlers.RescalingTriggerHandler - org.apache.flink.runtime.rest.handler.job.rescaling中的类
Handler which triggers the rescaling of the specified job.
rescalingParallelismQueryParameter - 类 中的变量org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
 
RescalingParallelismQueryParameter - org.apache.flink.runtime.rest.messages中的类
Parallelism for the rescaling of jobs specified as a MessageQueryParameter.
RescalingParallelismQueryParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
RescalingStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
 
RescalingStatusHeaders - org.apache.flink.runtime.rest.handler.job.rescaling中的类
Message headers for polling the status of an ongoing rescaling operation.
RescalingStatusMessageParameters - org.apache.flink.runtime.rest.handler.job.rescaling中的类
MessageParameters for polling the status of a rescaling operation.
RescalingStatusMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
 
RescalingTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
 
RescalingTriggerHeaders - org.apache.flink.runtime.rest.handler.job.rescaling中的类
Message headers for triggering the rescaling of a job.
RescalingTriggerMessageParameters - org.apache.flink.runtime.rest.handler.job.rescaling中的类
MessageParameters for triggering the rescaling of a job.
RescalingTriggerMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
 
reset(Collection<MasterTriggerRestoreHook<?>>, Logger) - 类 中的静态方法org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Resets the master hooks.
reset() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
reset() - 接口 中的方法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() - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
reset() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
reset() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
reset() - 类 中的方法org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
reset() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
reset() - 类 中的方法org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
reset() - 接口 中的方法org.apache.flink.runtime.operators.ResettableDriver
 
reset() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Resets the sort buffer back to the state where it is empty.
reset() - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Resets the sort buffer back to the state where it is empty.
reset() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Resets the sort buffer back to the state where it is empty.
reset() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter
 
reset() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
reset() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
reset() - 接口 中的方法org.apache.flink.runtime.util.ResettableIterator
Resets the iterator.
reset() - 接口 中的方法org.apache.flink.runtime.util.ResettableMutableObjectIterator
Resets the iterator.
resetAllInputs() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
resetConstraints() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Resets this co-location group, meaning that future calls to CoLocationGroup.getLocationConstraint(int) will give out new CoLocationConstraints.
resetEndOfSuperstep() - 类 中的方法org.apache.flink.runtime.iterative.task.SyncEventHandler
 
resetForNewExecution(long, long) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
resetForNewExecution(long, long) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Archives the current Execution and creates a new Execution for this vertex.
resetOverflowBuckets() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
resets overflow bucket counters and returns freed memory and should only be used for resizing
resetRecordCounter() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
sets record counter to zero and should only be used on compaction partition
resetRWViews() - 类 中的方法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> - 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 - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The resettable inputs in the case where no temp barrier is needed.
ResettableIterator<E> - 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> - 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) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
resizeQueueArray(int, int) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
resolve(RestartStrategies.RestartStrategyConfiguration, RestartStrategyFactory, boolean) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.RestartStrategyResolving
Resolves which RestartStrategy to use.
resolve(X) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
Resolves this parameter for the given value.
resolveCheckpoint(String) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
resolveCheckpoint(String) - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
 
resolveCheckpoint(String) - 类 中的方法org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
resolveCheckpoint(String) - 接口 中的方法org.apache.flink.runtime.state.StateBackend
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
resolveCheckpointPointer(String) - 类 中的静态方法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) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Resolves a storage location reference into a CheckpointStreamFactory.
resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
resolveFromString(String) - 类 中的方法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>) - 类 中的方法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. from a task-local source.
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<ArrayList<T>>) - 类 中的方法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>>) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
resolveUrl(String, MessageParameters) - 类 中的静态方法org.apache.flink.runtime.rest.messages.MessageParameters
Resolves the given URL (e.g "jobs/:jobid") using the given path/query parameters.
resource() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
resource() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
resource() - 接口 中的方法org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
Returns the resource if it is available, null otherwise.
RESOURCE_MANAGER_NAME - 类 中的静态变量org.apache.flink.runtime.resourcemanager.ResourceManager
 
ResourceActions - org.apache.flink.runtime.resourcemanager.slotmanager中的接口
Resource related actions which the SlotManager can perform.
resourceId() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RemoveResource
Gets the ID under which the resource is registered (for example container ID).
resourceId() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the ID under which the resource is registered (for example container ID).
ResourceID - org.apache.flink.runtime.clusterframework.types中的类
Class for Resource Ids identifying Flink's distributed components.
ResourceID(String) - 类 的构造器org.apache.flink.runtime.clusterframework.types.ResourceID
 
ResourceIDDeserializer - org.apache.flink.runtime.rest.messages.json中的类
Json deserializer for ResourceID.
ResourceIDDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
 
ResourceIDRetrievable - org.apache.flink.runtime.clusterframework.types中的接口
An interface to retrieve the ResourceID of an object.
ResourceIDSerializer - org.apache.flink.runtime.rest.messages.json中的类
Json serializer for InstanceID.
ResourceIDSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
 
resourceManager() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
resourceManager() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
ResourceManager<WorkerType extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager中的类
ResourceManager implementation.
ResourceManager(RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup) - 类 的构造器org.apache.flink.runtime.resourcemanager.ResourceManager
 
ResourceManagerAddress - org.apache.flink.runtime.jobmaster中的类
Current address and fencing token of the leading ResourceManager.
ResourceManagerAddress(String, ResourceManagerId) - 类 的构造器org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
ResourceManagerException - org.apache.flink.runtime.resourcemanager.exceptions中的异常错误
Base class for ResourceManager exceptions.
ResourceManagerException(String) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerFactory<T extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager中的接口
ResourceManagerGateway - org.apache.flink.runtime.resourcemanager中的接口
The ResourceManager's RPC gateway interface.
ResourceManagerId - org.apache.flink.runtime.resourcemanager中的类
Fencing token for the ResourceManager.
ResourceManagerRuntimeServices - org.apache.flink.runtime.resourcemanager中的类
Container class for the ResourceManager services.
ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - 类 的构造器org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
ResourceManagerRuntimeServicesConfiguration - org.apache.flink.runtime.resourcemanager中的类
Configuration class for the ResourceManagerRuntimeServices class.
ResourceManagerRuntimeServicesConfiguration(Time, SlotManagerConfiguration) - 类 的构造器org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
ResourceManagerServices - org.apache.flink.runtime.resourcemanager中的接口
Interface which provides access to services of the ResourceManager.
ResourceOverview - org.apache.flink.runtime.resourcemanager中的类
Class containing information about the available cluster resources.
ResourceOverview(int, int, int) - 类 的构造器org.apache.flink.runtime.resourcemanager.ResourceOverview
 
ResourceProfile - org.apache.flink.runtime.clusterframework.types中的类
Describe the immutable resource profile of the slot, either when requiring or offering it.
ResourceProfile(double, int, int, int, int, Map<String, Resource>) - 类 的构造器org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new ResourceProfile.
ResourceProfile(double, int) - 类 的构造器org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new simple ResourceProfile used for testing.
ResourceProfile(ResourceProfile) - 类 的构造器org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a copy of the given ResourceProfile.
ResourceRemoved - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the JobManager by the Resource Manager to inform about the removal of a resource.
ResourceRemoved(ResourceID, String) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Constructor for a shutdown of a registered resource.
respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractHandler
 
respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - 类 中的方法org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
 
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractHandler
Respond to the given HandlerRequest.
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
ResponseBody - org.apache.flink.runtime.rest.messages中的接口
Marker interface for all responses of the REST API.
responseHeaders - 类 中的变量org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
responseHeaders - 类 中的变量org.apache.flink.runtime.rest.RestServerEndpoint
 
REST_CONTENT_TYPE - 枚举 中的静态变量org.apache.flink.runtime.rest.util.RestConstants
 
REST_PORT_OPTION - 类 中的静态变量org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
 
RestAPIVersion - org.apache.flink.runtime.rest.versioning中的枚举
An enum for all versions of the REST API.
RestAPIVersion.RestAPIVersionComparator - org.apache.flink.runtime.rest.versioning中的类
Comparator for RestAPIVersion that sorts versions based on their version number, i.e. oldest to latest.
RestAPIVersionComparator() - 类 的构造器org.apache.flink.runtime.rest.versioning.RestAPIVersion.RestAPIVersionComparator
 
restart(long) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
restart(RestartCallback, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - 接口 中的方法org.apache.flink.runtime.executiongraph.restart.RestartStrategy
Called by the ExecutionGraph to eventually trigger a full recovery.
RestartAllStrategy - org.apache.flink.runtime.executiongraph.failover中的类
Simple failover strategy that triggers a restart of all tasks in the execution graph, via ExecutionGraph.failGlobal(Throwable).
RestartAllStrategy(ExecutionGraph) - 类 的构造器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 - org.apache.flink.runtime.executiongraph.failover中的类
Factory that instantiates the RestartAllStrategy.
RestartCallback - org.apache.flink.runtime.executiongraph.restart中的接口
A callback to trigger restarts, passed to the RestartStrategy to trigger recovery on the ExecutionGraph.
RestartIndividualStrategy - org.apache.flink.runtime.executiongraph.failover中的类
Simple failover strategy that restarts each task individually.
RestartIndividualStrategy(ExecutionGraph) - 类 的构造器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 - org.apache.flink.runtime.executiongraph.failover中的类
Factory that instantiates the RestartAllStrategy.
RestartPipelinedRegionStrategy - org.apache.flink.runtime.executiongraph.failover中的类
A failover strategy that restarts regions of the ExecutionGraph.
RestartPipelinedRegionStrategy(ExecutionGraph) - 类 的构造器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 - org.apache.flink.runtime.executiongraph.failover中的类
Factory that instantiates the RestartPipelinedRegionStrategy.
RestartStrategy - org.apache.flink.runtime.executiongraph.restart中的接口
Strategy for ExecutionGraph restarts.
RestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
 
RestartStrategyFactory() - 类 的构造器org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
 
RestartStrategyResolving - org.apache.flink.runtime.executiongraph.restart中的类
Utility method for resolving RestartStrategy.
RestartTimeGauge - org.apache.flink.runtime.executiongraph.metrics中的类
Gauge which returns the last restarting time.
RestartTimeGauge(ExecutionGraph) - 类 的构造器org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
RestClient - org.apache.flink.runtime.rest中的类
This client is the counter-part to the RestServerEndpoint.
RestClient(RestClientConfiguration, Executor) - 类 的构造器org.apache.flink.runtime.rest.RestClient
 
RestClientConfiguration - org.apache.flink.runtime.rest中的类
A configuration object for RestClients.
RestClientException - 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) - 异常错误 的构造器org.apache.flink.runtime.rest.util.RestClientException
 
RestClientException(String, Throwable, HttpResponseStatus) - 异常错误 的构造器org.apache.flink.runtime.rest.util.RestClientException
 
restConfiguration - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
RestConstants - org.apache.flink.runtime.rest.util中的枚举
This class contains constants to be used by rest components.
RestEndpointFactory<T extends RestfulGateway> - org.apache.flink.runtime.rest中的接口
RestfulGateway - org.apache.flink.runtime.webmonitor中的接口
Gateway for restful endpoints.
RestHandlerConfiguration - org.apache.flink.runtime.rest.handler中的类
Configuration object containing values for the rest handler configuration.
RestHandlerConfiguration(long, int, Time, File) - 类 的构造器org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
RestHandlerException - 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) - 异常错误 的构造器org.apache.flink.runtime.rest.handler.RestHandlerException
 
RestHandlerException(String, HttpResponseStatus, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rest.handler.RestHandlerException
 
RestHandlerSpecification - org.apache.flink.runtime.rest.handler中的接口
Rest handler interface which all rest handler implementation have to implement.
RestHandlerUrlComparator() - 类 的构造器org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
 
RestMapperUtils - org.apache.flink.runtime.rest.util中的类
This class contains utilities for mapping requests and responses to/from JSON.
RestMapperUtils() - 类 的构造器org.apache.flink.runtime.rest.util.RestMapperUtils
 
restore() - 类 中的方法org.apache.flink.runtime.state.heap.HeapRestoreOperation
 
restore() - 类 中的方法org.apache.flink.runtime.state.OperatorStateRestoreOperation
 
restore() - 接口 中的方法org.apache.flink.runtime.state.RestoreOperation
Restores state that was previously snapshot-ed from the provided state handles.
restoreCheckpoint(long, T) - 接口 中的方法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) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
RestoredCheckpointStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a restored checkpoint.
restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restores the latest checkpointed state.
restoreLatestCheckpointedState(boolean, boolean) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Restores the latest checkpointed state.
restoreMasterHooks(Map<String, MasterTriggerRestoreHook<?>>, Collection<MasterState>, long, boolean, Logger) - 类 中的静态方法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> - org.apache.flink.runtime.state中的接口
Interface for restore operation.
restoreSavepoint(String, boolean, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restore the state with given savepoint.
restoreSavepoint() - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether to restore from savepoint.
restoreStateHandles - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
restoreStateHandles - 类 中的变量org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
State handles for restore.
RestServerEndpoint - org.apache.flink.runtime.rest中的类
An abstract class for netty-based REST server endpoints.
RestServerEndpoint(RestServerEndpointConfiguration) - 类 的构造器org.apache.flink.runtime.rest.RestServerEndpoint
 
RestServerEndpoint.RestHandlerUrlComparator - org.apache.flink.runtime.rest中的类
Comparator for Rest URLs.
RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator - org.apache.flink.runtime.rest中的类
Comparator for Rest URLs.
RestServerEndpointConfiguration - org.apache.flink.runtime.rest中的类
A configuration object for RestServerEndpoints.
Result(StreamStateHandle, int) - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistry.Result
 
resultHandler - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handler for completed requests
ResultPartition - org.apache.flink.runtime.io.network.partition中的类
A result partition for data produced by a single task.
ResultPartition(String, TaskActions, JobID, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, boolean) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartition
 
ResultPartitionConsumableNotifier - org.apache.flink.runtime.io.network.partition中的接口
Interface for notifications about consumable partitions.
ResultPartitionDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
Deployment descriptor for a result partition.
ResultPartitionDeploymentDescriptor(IntermediateDataSetID, IntermediateResultPartitionID, ResultPartitionType, int, int, boolean) - 类 的构造器org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
ResultPartitionID - org.apache.flink.runtime.io.network.partition中的类
Runtime identifier of a produced IntermediateResultPartition.
ResultPartitionID() - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
ResultPartitionID(IntermediateResultPartitionID, ExecutionAttemptID) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
ResultPartitionLocation - org.apache.flink.runtime.deployment中的类
Location of a result partition from the perspective of the consuming task.
ResultPartitionManager - org.apache.flink.runtime.io.network.partition中的类
The result partition manager keeps track of all currently produced/consumed partitions of a task manager.
ResultPartitionManager() - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
ResultPartitionMetrics - org.apache.flink.runtime.io.network.partition中的类
Collects metrics of a result partition.
ResultPartitionProvider - org.apache.flink.runtime.io.network.partition中的接口
Interface for creating result partitions.
ResultPartitionType - org.apache.flink.runtime.io.network.partition中的枚举
Type of a result partition.
ResultPartitionWriter - org.apache.flink.runtime.io.network.api.writer中的接口
A buffer-oriented runtime result writer API for producing results.
ResultSubpartition - org.apache.flink.runtime.io.network.partition中的类
A single subpartition of a ResultPartition instance.
ResultSubpartition(int, ResultPartition) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
ResultSubpartition.BufferAndBacklog - 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 - org.apache.flink.runtime.io.network.partition中的接口
A view to consume a ResultSubpartition instance.
retain() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
retain(int) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
retainAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
retainAll(Collection<?>) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
retainBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Retains this buffer for further use, increasing the reference counter by 1.
retainBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
retainBuffer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
RetrievableStateHandle<T extends Serializable> - org.apache.flink.runtime.state中的接口
Handle to state that can be read back again via RetrievableStateHandle.retrieveState().
RetrievableStateStorageHelper<T extends Serializable> - 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> - org.apache.flink.runtime.state中的类
Wrapper around a StreamStateHandle to make the referenced state object retrievable trough a simple get call.
RetrievableStreamStateHandle(StreamStateHandle) - 类 的构造器org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
RetrievableStreamStateHandle(Path, long) - 类 的构造器org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
retrieveJobGraph(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
 
retrieveJobGraph(Configuration) - 接口 中的方法org.apache.flink.runtime.entrypoint.component.JobGraphRetriever
Retrieve the JobGraph.
retrieveLeaderConnectionInfo(LeaderRetrievalService, Time) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the leader akka url and the current leader session ID.
retrieveLeaderConnectionInfo(LeaderRetrievalService, FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the leader akka url and the current leader session ID.
retrieveLeaderGateway(LeaderRetrievalService, ActorSystem, FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader gateway using the given LeaderRetrievalService.
retrieveLeaderSessionId(LeaderRetrievalService, FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader session id of the component identified by the given leader retrieval service.
retrieveLocalState(long) - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
retrieveLocalState(long) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
retrievePayload(ResourceID) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatListener
Retrieves the payload value for the next heartbeat message.
retrieveService(String) - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
 
retrieveService(String) - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
Retrieves for the given query service path a MetricQueryServiceGateway.
retrieveState() - 接口 中的方法org.apache.flink.runtime.state.RetrievableStateHandle
Retrieves the object that was previously written to state.
retrieveState() - 类 中的方法org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
retriggerPartitionRequest(IntermediateResultPartitionID) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Retriggers a partition request.
retry(Supplier<CompletableFuture<T>>, int, Executor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
retry(Object, int, FiniteDuration, ExecutionContext) - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Retries to send asynchronously a message up to numberRetries times.
retry(Object, int, FiniteDuration, ExecutionContext) - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Retries to send asynchronously a message up to numberRetries times.
RetryException(String) - 异常错误 的构造器org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryingRegistration<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - 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) - 类 的构造器org.apache.flink.runtime.registration.RetryingRegistration
 
RetryingRegistrationConfiguration - org.apache.flink.runtime.registration中的类
Configuration for the cluster components.
RetryingRegistrationConfiguration(long, long, long, long) - 类 的构造器org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
 
retrySuccessfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
returnExclusiveSegments(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
The exclusive segments are recycled to network buffer pool directly when input channel is released.
returnLogicalSlot(LogicalSlot) - 类 中的方法org.apache.flink.runtime.instance.Instance
Returns a slot that has been allocated from this instance.
returnLogicalSlot(LogicalSlot) - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotOwner
Return the given slot to the slot owner.
returnLogicalSlot(LogicalSlot) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
reuseInputMetricsForTask() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators input record counter.
reuseOutputMetricsForTask() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators output record counter.
reuseRecordsInputCounter(Counter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
reuseRecordsOutputCounter(Counter) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
ReusingBlockResettableIterator<T> - 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) - 类 的构造器org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
ReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
ReusingBuildFirstHashJoinIterator<V1,V2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
ReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
 
ReusingBuildSecondHashJoinIterator<V1,V2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
ReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
 
ReusingDeserializationDelegate<T> - org.apache.flink.runtime.plugable中的类
A DeserializationDelegate that reuses an existing instance upon deserialization.
ReusingDeserializationDelegate(TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
ReusingKeyGroupedIterator<E> - 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>) - 类 的构造器org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Initializes the KeyGroupedIterator.
ReusingKeyGroupedIterator.ValuesIterator - org.apache.flink.runtime.util中的类
 
ReusingMergeInnerJoinIterator<T1,T2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
ReusingMergeOuterJoinIterator<T1,T2,O> - 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) - 类 的构造器org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
ReusingMutableToRegularIteratorWrapper<T> - org.apache.flink.runtime.util中的类
This class wraps a MutableObjectIterator into a regular Iterator.
ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
ReusingSortMergeCoGroupIterator<T1,T2> - org.apache.flink.runtime.operators.sort中的类
 
ReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - 类 的构造器org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
RevisionInformation(String, String) - 类 的构造器org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
 
revokeLeadership() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
Callback method when current resourceManager loses leadership.
revokeLeadership() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
revokeLeadership() - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon revoking the leadership of a former leader.
revokeLeadership() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager loses leadership.
revokeLeadership() - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
RightOuterJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
The right outer join driver implements the logic of an outer join operator at runtime.
RightOuterJoinDriver() - 类 的构造器org.apache.flink.runtime.operators.RightOuterJoinDriver
 
ROCKSDB_STATE_BACKEND_NAME - 类 中的静态变量org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the RocksDB State Backend
roundDownToPageSizeMultiple(long) - 类 中的方法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> - org.apache.flink.runtime.io.network.api.writer中的类
This is the default implementation of the ChannelSelector interface.
RoundRobinChannelSelector() - 类 的构造器org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
RoundRobinOperatorStateRepartitioner - org.apache.flink.runtime.checkpoint中的类
Current default implementation of OperatorStateRepartitioner that redistributes state in round robin fashion.
RoundRobinOperatorStateRepartitioner() - 类 的构造器org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
route(HttpMethod, String) - 类 中的方法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>>) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
 
RoutedRequest<T> - org.apache.flink.runtime.rest.handler.router中的类
Class for handling HttpRequest with associated RouteResult.
RoutedRequest(RouteResult<T>, HttpRequest) - 类 的构造器org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
Router<T> - org.apache.flink.runtime.rest.handler.router中的类
This is adopted and simplified code from tv.cntt:netty-router library.
Router() - 类 的构造器org.apache.flink.runtime.rest.handler.router.Router
 
RouteResult<T> - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.router.RouteResult
The maps will be wrapped in Collections.unmodifiableMap.
RouterHandler - 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>) - 类 的构造器org.apache.flink.runtime.rest.handler.router.RouterHandler
 
RpcCheckpointResponder - org.apache.flink.runtime.taskexecutor.rpc中的类
 
RpcCheckpointResponder(CheckpointCoordinatorGateway) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
RpcConnectionException - org.apache.flink.runtime.rpc.exceptions中的异常错误
Exception class which is thrown if a rpc connection failed.
RpcConnectionException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcEndpoint - org.apache.flink.runtime.rpc中的类
Base class for RPC endpoints.
RpcEndpoint(RpcService, String) - 类 的构造器org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint.
RpcEndpoint(RpcService) - 类 的构造器org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint with a random endpoint id.
RpcEndpoint.MainThreadExecutor - org.apache.flink.runtime.rpc中的类
Executor which executes runnables in the main thread context.
RpcException - org.apache.flink.runtime.rpc.exceptions中的异常错误
Base class for RPC related exceptions.
RpcException(String) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcGateway - org.apache.flink.runtime.rpc中的接口
Rpc gateway interface which has to be implemented by Rpc gateways.
RpcGatewayRetriever<F extends Serializable,T extends FencedRpcGateway<F>> - org.apache.flink.runtime.webmonitor.retriever.impl中的类
LeaderGatewayRetriever implementation using the RpcService.
RpcGatewayRetriever(RpcService, Class<T>, Function<UUID, F>, int, Time) - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
 
RpcGlobalAggregateManager - org.apache.flink.runtime.taskexecutor.rpc中的类
 
RpcGlobalAggregateManager(JobMasterGateway) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcGlobalAggregateManager
 
RpcInputSplitProvider - org.apache.flink.runtime.taskexecutor.rpc中的类
 
RpcInputSplitProvider(JobMasterGateway, JobVertexID, ExecutionAttemptID, Time) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
 
RpcInvocation - org.apache.flink.runtime.rpc.messages中的接口
Interface for rpc invocation messages.
RpcKvStateRegistryListener - org.apache.flink.runtime.taskexecutor.rpc中的类
KvStateRegistryListener implementation for the new RPC service.
RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
RpcPartitionStateChecker - org.apache.flink.runtime.taskexecutor.rpc中的类
 
RpcPartitionStateChecker(JobMasterGateway) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
 
RpcResultPartitionConsumableNotifier - org.apache.flink.runtime.taskexecutor.rpc中的类
 
RpcResultPartitionConsumableNotifier(JobMasterGateway, Executor, Time) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
rpcServer - 类 中的变量org.apache.flink.runtime.rpc.RpcEndpoint
Interface to access the underlying rpc server.
RpcServer - org.apache.flink.runtime.rpc中的接口
Interface for self gateways.
RpcService - org.apache.flink.runtime.rpc中的接口
Interface for rpc services.
RpcServiceSharing - 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 - org.apache.flink.runtime.jobmaster中的类
Implementation of the TaskManagerGateway for Flink's RPC system.
RpcTaskManagerGateway(TaskExecutorGateway, JobMasterId) - 类 的构造器org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RpcTimeout - org.apache.flink.runtime.rpc中的注释类型
Annotation for RpcGateway methods to specify an additional timeout parameter for the returned future to be completed.
RpcUtils - org.apache.flink.runtime.rpc中的类
Utility functions for Flink's RPC implementation.
run() - 类 中的方法org.apache.flink.runtime.blob.BlobServer
 
run() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
run() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
run() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationHeadTask
 
run() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationIntermediateTask
 
run() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationTailTask
 
run() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
run() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
 
run() - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
run() - 接口 中的方法org.apache.flink.runtime.operators.Driver
The main operation method of the task.
run() - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
run() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Implements exception handling and delegates to go().
run() - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
run() - 类 中的方法org.apache.flink.runtime.state.DoneFuture
 
run() - 类 中的方法org.apache.flink.runtime.taskmanager.MemoryLogger
 
run() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
The core work method that bootstraps the task and executes its code.
run() - 类 中的方法org.apache.flink.runtime.util.JvmShutdownSafeguard
 
run() - 类 中的方法org.apache.flink.runtime.util.ProcessShutDownThread
 
runAfterwards(CompletableFuture<?>, RunnableWithException) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAsync(Runnable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
Execute the runnable in the main thread of the underlying RPC endpoint.
runAsync(Runnable) - 接口 中的方法org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the runnable in the main thread of the underlying RPC endpoint.
RunAsync - org.apache.flink.runtime.rpc.messages中的类
Message for asynchronous runnable invocations
RunAsync(Runnable, long) - 类 的构造器org.apache.flink.runtime.rpc.messages.RunAsync
Creates a new RunAsync message.
runAsync(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
runAsync(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint.
runAsyncWithoutFencing(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
runAsyncWithoutFencing(Runnable) - 接口 中的方法org.apache.flink.runtime.rpc.FencedMainThreadExecutable
Run the given runnable in the main thread without attaching a fencing token.
runAsyncWithoutFencing(Runnable) - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
Run the given runnable in the main thread of the RpcEndpoint without checking the fencing token.
runClusterEntrypoint(ClusterEntrypoint) - 类 中的静态方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
runDetached(JobGraph) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
This method executes a job in detached mode.
runFlinkZkQuorumPeer(String, int) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Run the given RunnableFuture if it is not done, and then retrieves its result.
running - 类 中的变量org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
running - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The flag that tags the task as still running.
running - 类 中的变量org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
running - 类 中的变量org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
running - 类 中的变量org.apache.flink.runtime.operators.JoinDriver
 
running - 类 中的变量org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
running - 类 中的变量org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
RunningJobsRegistry - org.apache.flink.runtime.highavailability中的接口
A simple registry that tracks if a certain job is pending execution, running, or completed.
RunningJobsRegistry.JobSchedulingStatus - org.apache.flink.runtime.highavailability中的枚举
The scheduling status of a job, as maintained by the RunningJobsRegistry.
runSecured(Callable<T>) - 接口 中的方法org.apache.flink.runtime.security.SecurityContext
 
runTaskManager(Configuration, ResourceID) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
RUNTIME_FAILURE_RETURN_CODE - 类 中的静态变量org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
RUNTIME_FAILURE_RETURN_CODE - 类 中的静态变量org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
RuntimeAggregatorRegistry - org.apache.flink.runtime.iterative.task中的类
 
RuntimeAggregatorRegistry(Collection<AggregatorWithName<?>>) - 类 的构造器org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
RuntimeEnvironment - org.apache.flink.runtime.taskmanager中的类
In implementation of the Environment.
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) - 类 的构造器org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
RuntimeEvent - org.apache.flink.runtime.event中的类
Subclasses of this event are recognized as events exchanged by the core runtime.
RuntimeEvent() - 类 的构造器org.apache.flink.runtime.event.RuntimeEvent
 
runtimeUdfContext - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The udf's runtime context.

S

Savepoint - org.apache.flink.runtime.checkpoint.savepoint中的接口
Savepoints are manually-triggered snapshots from which a program can be resumed on submission.
SavepointDisposalHandlers - org.apache.flink.runtime.rest.handler.job.savepoints中的类
Handlers to trigger the disposal of a savepoint.
SavepointDisposalHandlers() - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers
 
SavepointDisposalHandlers.SavepointDisposalStatusHandler - org.apache.flink.runtime.rest.handler.job.savepoints中的类
StatusHandler implementation for the savepoint disposal operation.
SavepointDisposalHandlers.SavepointDisposalTriggerHandler - org.apache.flink.runtime.rest.handler.job.savepoints中的类
TriggerHandler implementation for the savepoint disposal operation.
SavepointDisposalRequest - org.apache.flink.runtime.rest.messages.job.savepoints中的类
Request body for a savepoint disposal call.
SavepointDisposalRequest(String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
 
SavepointDisposalStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
 
SavepointDisposalStatusHeaders - org.apache.flink.runtime.rest.messages.job.savepoints中的类
AsynchronousOperationTriggerMessageHeaders implementation for the SavepointDisposalHandlers.SavepointDisposalStatusHandler.
SavepointDisposalStatusMessageParameters - org.apache.flink.runtime.rest.messages.job.savepoints中的类
MessageParameters for the SavepointDisposalHandlers.SavepointDisposalStatusHandler.
SavepointDisposalStatusMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
 
SavepointDisposalTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
 
SavepointDisposalTriggerHeaders - org.apache.flink.runtime.rest.messages.job.savepoints中的类
AsynchronousOperationTriggerMessageHeaders for the SavepointDisposalHandlers.SavepointDisposalTriggerHandler.
SavepointHandlers - org.apache.flink.runtime.rest.handler.job.savepoints中的类
HTTP handlers for asynchronous triggering of savepoints.
SavepointHandlers(String) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers
 
SavepointHandlers.SavepointStatusHandler - org.apache.flink.runtime.rest.handler.job.savepoints中的类
HTTP handler to query for the status of the savepoint.
SavepointHandlers.SavepointTriggerHandler - org.apache.flink.runtime.rest.handler.job.savepoints中的类
HTTP handler to trigger savepoints.
SavepointInfo - org.apache.flink.runtime.rest.messages.job.savepoints中的类
Represents information about a finished savepoint.
SavepointInfo(String, SerializedThrowable) - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
 
SavepointRestoreSettings - org.apache.flink.runtime.jobgraph中的类
Savepoint restore settings.
SavepointSerializer<T extends Savepoint> - org.apache.flink.runtime.checkpoint.savepoint中的接口
Serializer for Savepoint instances.
SavepointSerializers - org.apache.flink.runtime.checkpoint.savepoint中的类
Helper to access SavepointSerializer for a specific savepoint version.
SavepointStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
SavepointStatusHeaders - org.apache.flink.runtime.rest.messages.job.savepoints中的类
These headers define the protocol for triggering a savepoint.
SavepointStatusMessageParameters - org.apache.flink.runtime.rest.messages.job.savepoints中的类
The parameters for triggering a savepoint.
SavepointStatusMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
 
SavepointTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
 
SavepointTriggerHeaders - org.apache.flink.runtime.rest.messages.job.savepoints中的类
These headers define the protocol for triggering a savepoint.
SavepointTriggerMessageParameters - org.apache.flink.runtime.rest.messages.job.savepoints中的类
The parameters for triggering a savepoint.
SavepointTriggerMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
 
SavepointTriggerRequestBody - org.apache.flink.runtime.rest.messages.job.savepoints中的类
RequestBody to trigger savepoints.
SavepointTriggerRequestBody(String, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
SavepointV1 - org.apache.flink.runtime.checkpoint.savepoint中的类
Savepoint version 0.
SavepointV1(long, Collection<TaskState>) - 类 的构造器org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
SavepointV1Serializer - org.apache.flink.runtime.checkpoint.savepoint中的类
Deserializer for checkpoints written in format 1 (Flink 1.2.x format) In contrast to the previous versions, this serializer makes sure that no Java serialization is used for serialization.
SavepointV2 - org.apache.flink.runtime.checkpoint.savepoint中的类
The persistent checkpoint metadata, format version 2.
SavepointV2(long, Collection<TaskState>) - 类 的构造器org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
已过时。
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
SavepointV2(long, Collection<OperatorState>, Collection<MasterState>) - 类 的构造器org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
SavepointV2Serializer - org.apache.flink.runtime.checkpoint.savepoint中的类
(De)serializer for checkpoint metadata format version 2.
ScalaUtils - org.apache.flink.runtime.util中的类
Utilities to convert Scala types into Java types.
schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
schedule(Runnable, long, TimeUnit) - 接口 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command after the given delay.
schedule(Callable<V>, long, TimeUnit) - 接口 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given callable after the given delay.
schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
scheduleAll(SlotProvider, boolean, LocationPreferenceConstraint, Set<AllocationID>) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Schedules all execution vertices of this ExecutionJobVertex.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 接口 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
ScheduledExecutor - org.apache.flink.runtime.concurrent中的接口
Extension for the Executor interface which is enriched by method for scheduling tasks in the future.
ScheduledExecutorServiceAdapter - org.apache.flink.runtime.concurrent中的类
Adapter class for a ScheduledExecutorService which shall be used as a ScheduledExecutor.
ScheduledExecutorServiceAdapter(ScheduledExecutorService) - 类 的构造器org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledFutureAdapter<V> - org.apache.flink.runtime.concurrent中的类
Adapter from Future to ScheduledFuture.
ScheduledFutureAdapter(Future<V>, long, TimeUnit) - 类 的构造器org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
 
ScheduledUnit - org.apache.flink.runtime.jobmanager.scheduler中的类
ScheduledUnit contains the information necessary to allocate a slot for the given JobVertexID.
ScheduledUnit(Execution) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroupId) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroupId, CoLocationConstraint) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(JobVertexID, SlotSharingGroupId, CoLocationConstraint) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, JobVertexID, SlotSharingGroupId, CoLocationConstraint) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
scheduleForExecution() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint, Set<AllocationID>) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint, Set<AllocationID>) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
Schedules the current execution of this ExecutionVertex.
ScheduleMode - org.apache.flink.runtime.jobgraph中的枚举
The ScheduleMode decides how tasks of an execution graph are started.
scheduleOrUpdateConsumers(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Schedule or updates consumers of the given result partition.
scheduleOrUpdateConsumers(ResultPartitionID, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
scheduleOrUpdateConsumers(ResultPartitionID, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Notifies the JobManager about available data for a produced partition.
Scheduler - org.apache.flink.runtime.jobmanager.scheduler中的类
The scheduler is responsible for distributing the ready-to-run tasks among instances and slots.
Scheduler(Executor) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Creates a new scheduler.
Scheduler - org.apache.flink.runtime.jobmaster.slotpool中的接口
Basic interface for the current scheduler, which is a SlotProvider and a SlotOwner.
SchedulerFactory - org.apache.flink.runtime.jobmaster.slotpool中的接口
Factory interface for Scheduler.
SchedulerImpl - org.apache.flink.runtime.jobmaster.slotpool中的类
Scheduler that assigns tasks to slots.
SchedulerImpl(SlotSelectionStrategy, SlotPool) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
SchedulerImpl(SlotSelectionStrategy, SlotPool, Map<SlotSharingGroupId, SlotSharingManager>) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
scheduleRunAsync(Runnable, Time) - 类 中的方法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) - 类 中的方法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) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
scheduleRunAsync(Runnable, Time) - 类 中的方法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) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
scheduleRunnable(Runnable, long, TimeUnit) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Execute the runnable in the execution context of this RPC Service, as returned by RpcService.getExecutor(), after a scheduled delay.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 接口 中的方法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) - 类 中的方法org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
scope - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo
The remaining scope not covered by specific fields.
SCOPE_HOST - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_INHERIT_PARENT - 类 中的静态变量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 - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_JOB_NAME - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_OPERATOR_ID - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_OPERATOR_NAME - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_SEPARATOR - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_ATTEMPT_ID - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_ATTEMPT_NUM - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_NAME - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_SUBTASK_INDEX - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_VERTEX_ID - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASKMANAGER_ID - 类 中的静态变量org.apache.flink.runtime.metrics.scope.ScopeFormat
 
ScopeFormat - 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[]) - 类 的构造器org.apache.flink.runtime.metrics.scope.ScopeFormat
 
ScopeFormats - org.apache.flink.runtime.metrics.scope中的类
A container for component scope formats.
scopeInfo - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump
The scope information for the stored metric.
secondDam() - 枚举 中的方法org.apache.flink.runtime.operators.DriverStrategy
 
SecureAclProvider() - 类 的构造器org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
SecurityConfiguration - org.apache.flink.runtime.security中的类
The global security configuration.
SecurityConfiguration(Configuration) - 类 的构造器org.apache.flink.runtime.security.SecurityConfiguration
Create a security configuration from the global configuration.
SecurityConfiguration(Configuration, List<SecurityModuleFactory>) - 类 的构造器org.apache.flink.runtime.security.SecurityConfiguration
Create a security configuration from the global configuration.
SecurityContext - org.apache.flink.runtime.security中的接口
A security context with may be required to run a Callable.
SecurityInstallException(String) - 异常错误 的构造器org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
 
SecurityInstallException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
 
SecurityModule - org.apache.flink.runtime.security.modules中的接口
An installable security module.
SecurityModule.SecurityInstallException - org.apache.flink.runtime.security.modules中的异常错误
Indicates a problem with installing or uninstalling a security module.
SecurityModuleFactory - org.apache.flink.runtime.security.modules中的接口
A factory for a SecurityModule.
SecurityUtils - org.apache.flink.runtime.security中的类
Utils for configuring security.
seek(long) - 类 中的方法org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
SeekableFileChannelInputView - 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) - 类 的构造器org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
seekInput(MemorySegment, int, int) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
Sets the internal state to the given memory segment and the given position within the segment.
seekTo(long) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
seekTo(long) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
seekToPosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
 
seekToPosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
seekToPosition(long) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
 
seekToPosition(long) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
seekToPosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
segmentSize - 类 中的变量org.apache.flink.runtime.memory.AbstractPagedOutputView
 
segmentSize - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The size of the segments used by the hash join buckets.
select(ExecutionMode, ShipStrategyType, boolean) - 枚举 中的静态方法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) - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns a specific allocation base directory.
selectAllocationBaseDirectory(int) - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
selectBestSlotForProfile(Collection<? extends SlotInfo>, SlotProfile) - 枚举 中的方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
 
selectBestSlotForProfile(Collection<? extends SlotInfo>, SlotProfile) - 枚举 中的方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
 
selectBestSlotForProfile(Collection<? extends SlotInfo>, SlotProfile) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy
Selects the best SlotInfo w.r.t. a certain selection criterion from the provided list of available slots and considering the given SlotProfile that describes the requirements.
selectChannel(T) - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelector
Returns the logical channel index, to which the given record should be written.
selectChannel(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
selectChannel(SerializationDelegate<T>) - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputEmitter
 
selectSubtaskBaseDirectory(int) - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns a specific subtask base directory.
selectSubtaskBaseDirectory(int) - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
SEND_RECEIVE_BUFFER_SIZE - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
sendErrorResponse(ChannelHandlerContext, HttpRequest, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerUtils
Sends the given error response and status code to the given channel.
sendInfoMessage(String) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
sendNotModified(ChannelHandlerContext) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Send the "304 Not Modified" response.
sendReadRequest(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Sends a new read requests, if further requests remain.
sendRequest(String, int, M) - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
sendRequest(String, int, M, U, R) - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
sendRequest(String, int, M, U, R, Collection<FileUpload>) - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
sendRequest(String, int, M, U, R, Collection<FileUpload>, RestAPIVersion) - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
sendResponse(ChannelHandlerContext, HttpRequest, P, HttpResponseStatus, Map<String, String>) - 类 中的静态方法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>) - 类 中的静态方法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>) - 类 中的静态方法org.apache.flink.runtime.rest.handler.util.HandlerUtils
Sends the given response and status code to the given channel.
sendScheduleOrUpdateConsumersMessage() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
 
sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the given SlotReport to the ResourceManager.
sendTaskEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
sendTaskEvent(TaskEvent) - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - 类 中的方法org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Sends a task event backwards to an intermediate result partition producer.
sendTaskEvent(TaskEvent) - 接口 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
sendTaskEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
sendTaskEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
SerializationDelegate<T> - 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>) - 类 的构造器org.apache.flink.runtime.plugable.SerializationDelegate
 
serialize(T, DataOutputStream) - 接口 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Serializes a savepoint to an output stream.
serialize(SavepointV2, DataOutputStream) - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serialize(SavepointV2, DataOutputStream) - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
serialize(JobDetails, JsonGenerator, SerializerProvider) - 类 中的方法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>>) - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
Serializes the given metrics and returns the resulting byte array.
serialize(CheckpointConfigInfo.ProcessingMode, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
 
serialize(AggregatedMetricsResponseBody, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
 
serialize(MetricCollectionResponseBody, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
 
serialize(JobConfigInfo, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
 
serialize(JobPlanInfo.RawJson, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
 
serialize(JobID, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobIDSerializer
 
serialize(JobResult, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobResultSerializer
 
serialize(JobVertexID, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
 
serialize(JobVertexID, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
 
serialize(ResourceID, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
 
serialize(SerializedThrowable, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
 
serialize(SerializedValue<?>, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
 
serialize(TriggerId, JsonGenerator, SerializerProvider) - 类 中的方法org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
 
serialize(ArrayList<T>, DataOutputView) - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
serialize(VoidNamespace, DataOutputView) - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
serializeAndTryOffload(T, JobID, BlobWriter) - 接口 中的静态方法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 - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
serializedGauges - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
serializedHistograms - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
SerializedInputSplit - org.apache.flink.runtime.jobmaster中的类
 
SerializedInputSplit(byte[]) - 类 的构造器org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
SerializedJobExecutionResult - 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>>>) - 类 的构造器org.apache.flink.runtime.client.SerializedJobExecutionResult
Creates a new SerializedJobExecutionResult.
serializedMeters - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
serializedThrowable(SerializedThrowable) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult.Builder
 
SerializedThrowableDeserializer - org.apache.flink.runtime.rest.messages.json中的类
JSON deserializer for SerializedThrowable.
SerializedThrowableDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
 
SerializedThrowableSerializer - org.apache.flink.runtime.rest.messages.json中的类
JSON serializer for SerializedThrowable.
SerializedThrowableSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
 
SerializedUpdateBuffer - org.apache.flink.runtime.iterative.io中的类
AbstractPagedOutputView used by the BlockingBackChannel for transmitting superstep results.
SerializedUpdateBuffer() - 类 的构造器org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
SerializedUpdateBuffer(List<MemorySegment>, int, IOManager) - 类 的构造器org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
serializedValue - 类 中的变量org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
The serialized value.
SerializedValueDeserializer - org.apache.flink.runtime.rest.messages.json中的类
JSON deserializer for SerializedValue.
SerializedValueDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
 
SerializedValueDeserializer(JavaType) - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
 
serializedValueKey - 类 中的变量org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
The key of the offloaded value BLOB.
SerializedValueSerializer - org.apache.flink.runtime.rest.messages.json中的类
JSON serializer for SerializedValue.
SerializedValueSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
 
SerializedValueSerializer(JavaType) - 类 的构造器org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
 
serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
serializeOld(SavepointV1, DataOutputStream) - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
serializer - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
serializer - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
serializer - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
Serializer() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
 
Serializer() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
 
Serializer() - 类 的构造器org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
 
Serializer() - 类 的构造器org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
 
serializer1 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
serializer2 - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
serializeRecord(T) - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Starts serializing the given record to an intermediate data buffer.
serializeRecord(T) - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
Serializes the complete record to an intermediate data serialization buffer.
serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
 
serverAddress - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
 
ServicesThreadFactory - org.apache.flink.runtime.highavailability中的类
 
ServicesThreadFactory() - 类 的构造器org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
SessionClusterEntrypoint - org.apache.flink.runtime.entrypoint中的类
Base class for session cluster entry points.
SessionClusterEntrypoint(Configuration) - 类 的构造器org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
 
SessionDispatcherFactory - org.apache.flink.runtime.dispatcher中的枚举
SessionDispatcherResourceManagerComponentFactory - org.apache.flink.runtime.entrypoint.component中的类
DispatcherResourceManagerComponentFactory for a SessionDispatcherResourceManagerComponent.
SessionDispatcherResourceManagerComponentFactory(ResourceManagerFactory<?>) - 类 的构造器org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
 
SessionDispatcherResourceManagerComponentFactory(DispatcherFactory<Dispatcher>, ResourceManagerFactory<?>) - 类 的构造器org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
 
SessionRestEndpointFactory - org.apache.flink.runtime.rest中的枚举
set(int) - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
Sets the bit at specified index.
set(int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Sets the bit at specified index.
set(int, T) - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
set(E) - 类 中的方法org.apache.flink.runtime.util.SingleElementIterator
Resets the element.
setAccumulators(Map<String, Accumulator<?, ?>>) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Update accumulators (discarded when the Execution has already been terminated).
setAlignmentDurationNanos(long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setAllocator(ByteBufAllocator) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Sets the buffer allocator for use in netty.
setAllocator(ByteBufAllocator) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setAllocator(ByteBufAllocator) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
setAllowQueuedScheduling(boolean) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
setAsyncDurationMillis(long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setBitsLocation(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter
 
setBlobServerAddress(InetSocketAddress) - 类 中的方法org.apache.flink.runtime.blob.AbstractBlobCache
Sets the address of the BlobServer.
setBlobServerAddress(InetSocketAddress) - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
Sets the address of the BlobServer.
setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastInputName(String, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - 类 中的方法org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
setBufferPool(BufferPool) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
setBytes(int, ByteBuf, int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, byte[], int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, ByteBuffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, InputStream, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, ScatteringByteChannel, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, FileChannel, long, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytesBufferedInAlignment(long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setCachable(boolean) - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setCancellerHandle(ScheduledFuture<?>) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
Sets the handle for the canceller to this pending checkpoint.
setChannelIndex(int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
setCheckpointStatsTracker(CheckpointStatsTracker) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Sets the checkpoint stats tracker.
setClasspaths(List<URL>) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Sets the classpaths required to run the job on a task manager.
setCommonBindAddress(String) - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setConfigDir(String) - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setConfigDir(String) - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
setConfiguration(Configuration) - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setContentTypeHeader(HttpResponse, File) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Sets the content type header for the HTTP Response.
setConvergenceCriterion(String, ConvergenceCriterion<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setCount(long) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Sets the current checkpoint ID.
setCount(long) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
setCount(long) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
setCurrentKey(K) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
setCurrentKey(K) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
Sets the current key that is used for partitioned state.
setCurrentNamespace(N) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
 
setCurrentNamespace(N) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
Sets the current namespace, which will be used when using the state access methods.
setDateAndCacheHeaders(HttpResponse, File) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Sets the "date" and "cache" headers for the HTTP Response.
setDateHeader(FullHttpResponse) - 类 中的静态方法org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Sets the "date" header for the HTTP response.
setDest(Path) - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setDriver(Class<? extends Driver>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverComparator(TypeComparatorFactory<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverPairComparator(TypePairComparatorFactory<?, ?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverStrategy(DriverStrategy) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setEndOffsetExclusive(long) - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
setError(Throwable) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
 
setExecutable(boolean) - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setExecutionConfig(ExecutionConfig) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Sets the execution config.
setExtract(boolean) - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setFailWhenLegacyStateDetected(boolean) - 类 中的静态方法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) - 类 中的方法org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
setField(TtlValue<T>, int, Object) - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
setFilehandlesDriver(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setFilehandlesInput(int, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setFormatDescription(String) - 类 中的方法org.apache.flink.runtime.jobgraph.InputFormatVertex
 
setFormatDescription(String) - 类 中的方法org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
setFurtherPatitioning(boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setHost(String) - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
Sets the default convergence criterion of a DeltaIteration
setInitialState(JobManagerTaskRestore) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Sets the initial state for the execution.
setInputAsynchronouslyMaterialized(int, boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setInputCached(int, boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setInputChannel(IntermediateResultPartitionID, InputChannel) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
setInputComparator(TypeComparatorFactory<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setInputDependencyConstraint(InputDependencyConstraint) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setInputLocalStrategy(int, LocalStrategy) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setInputSerializer(TypeSerializerFactory<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setInputSplitSource(InputSplitSource<?>) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setInstance(T) - 接口 中的方法org.apache.flink.runtime.plugable.DeserializationDelegate
 
setInstance(T) - 类 中的方法org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
setInstance(T) - 类 中的方法org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
setInstance(T) - 类 中的方法org.apache.flink.runtime.plugable.SerializationDelegate
 
setInternalIndex(int) - 接口 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
Sets the current index of this object in the HeapPriorityQueue and should only be called by the owning HeapPriorityQueue.
setInvokableClass(Class<? extends AbstractInvokable>) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setIsCompacted(boolean) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIsSolutionSetUpdateWithoutReprobe() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIsWorksetIteration() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIsWorksetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadFinalOutputConfig(TaskConfig) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadIndexOfSyncOutput(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadPartialSolutionOrWorksetInputIndex(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadSolutionSetInputIndex(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationId(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setIterativeReader() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
setIterativeReader() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
setJobFinished(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobFinished(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobFinished(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as completed.
setJobFinished(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJobManagerMode(String) - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setJobRunning(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobRunning(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobRunning(JobID) - 接口 中的方法org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as running.
setJobRunning(JobID) - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJsonPlan(String) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setKeyGroupOffset(int, long) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
Sets the offset for the given key-group.
setLastOutputCollector(Collector<OT>) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
Sets the last output Collector of the collector chain of this BatchTask.
setLocality(Locality) - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
Attached locality information to this slot.
setMaxParallelism(int) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
setMaxParallelism(int) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Sets the maximum parallelism for the task.
setMemorySegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
 
setMemorySegment(MemorySegment, int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
setMetaInfo(RegisteredKeyValueStateBackendMetaInfo<N, S>) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
setMetaInfo(RegisteredKeyValueStateBackendMetaInfo<N, S>) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
setMetricGroup(TaskIOMetricGroup) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
Sets the metric group for this RecordWriter.
setMoreAvailable(boolean) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
setMutableObjectMode(boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setName(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Sets the name of the vertex
setNextBuffer(Buffer) - 接口 中的方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
setNextBuffer(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
setNumberOfIterations(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setNumBuffers(int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPool
Sets the current size of this buffer pool.
setNumSlotsPerTaskManager(int) - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setNumTaskManagers(int) - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setOperatorDescription(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorLevelCachingDescription(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Sets the operator-level caching description for this input.
setOperatorName(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorPrettyName(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setOutputCollector(Collector<?>) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setOutputComparator(TypeComparatorFactory<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputDataDistribution(DataDistribution, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputPartitioner(Partitioner<?>, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputSerializer(TypeSerializerFactory<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setParallelism(int) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Sets the parallelism for the task.
setPartition(int, IntermediateResultPartition) - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
setPartitionNumber(int) - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
overwrites partition number and should only be used on compaction partition
setPoolName(String) - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
 
setPreProcessingOperationName(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Sets the name of the pre-processing operation for this input.
setPreviousSerializerSnapshotForRestoredState(TypeSerializerSnapshot<T>) - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
For restored state, set the state's previous serializer's snapshot.
SetQueue<E> - 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() - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
setQueuedSchedulingAllowed(boolean) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setReaderIndex(int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Sets the reader index of this buffer.
setReaderIndex(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setReaderIndex(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
setReadPosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessInputView
 
setReadPosition(long) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
 
setRegisteredAsAvailable(boolean) - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
Updates the value to indicate whether the reader is enqueued in the pipeline or not.
setRelativeBackChannelMemory(double) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeInputMaterializationMemory(int, double) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeMemoryDriver(double) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeMemoryInput(int, double) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeSolutionSetMemory(double) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setRequestFuture(CompletableFuture<Acknowledge>) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
setResources(ResourceSpec, ResourceSpec) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Sets the minimum and preferred resources for the task.
setResultIterator(MutableObjectIterator<E>) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Sets the result iterator.
setResultIteratorException(IOException) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Reports an exception to all threads that are waiting for the result iterator.
setResultOptimizerProperties(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
setRpcServiceSharing(RpcServiceSharing) - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setSavepointRestoreSettings(SavepointRestoreSettings) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Sets the savepoint restore settings.
setScheduleMode(ScheduleMode) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setScheduleMode(ScheduleMode) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
setSessionTimeout(long) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Sets the timeout of the session in seconds.
setSharedSlot(SharedSlot) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Assigns a new shared slot to this co-location constraint.
setShipStrategyName(String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
Sets the name of the ship strategy for the represented input.
setShouldInterruptOnCancel(boolean) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Sets whether the thread that executes the AbstractInvokable.invoke() method should be interrupted during cancellation.
setSize(int) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Sets the size of the written data, i.e. the writer index, of this buffer.
setSize(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setSize(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
setSlotAvailabilityListener(SlotAvailabilityListener) - 类 中的方法org.apache.flink.runtime.instance.Instance
Sets the listener that receives notifications for slot availability.
setSlotRequestId(SlotRequestId) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Sets the slot request id of the currently assigned slot to the co-location constraint.
setSlotSharingGroup(SlotSharingGroup) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
Associates this vertex with a slot sharing group for scheduling.
setSnapshotSettings(JobCheckpointingSettings) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
Sets the settings for asynchronous snapshots.
setSolutionSetComparator(TypeComparatorFactory<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setSolutionSetSerializer(TypeSerializerFactory<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setSolutionSetUnmanaged(boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setSource(Path) - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setSpillingThresholdDriver(float) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setSpillingThresholdInput(int, float) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setState(S, int) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - 接口 中的方法org.apache.flink.runtime.state.BackendWritableBroadcastState
 
setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
setStateMetaInfo(RegisteredOperatorStateBackendMetaInfo<S>) - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
setStrictlyCoLocatedWith(JobVertex) - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setStubParameters(Configuration) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setStubWrapper(UserCodeWrapper<?>) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setSyncDurationMillis(long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
SettableLeaderRetrievalService - org.apache.flink.runtime.leaderretrieval中的类
LeaderRetrievalService implementation which directly forwards calls of notifyListener to the listener.
SettableLeaderRetrievalService() - 类 的构造器org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
SettableLeaderRetrievalService(String, UUID) - 类 的构造器org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
setTaskName(String) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setThreadPriority(int) - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
 
setUdfConfiguration(Configuration) - 类 中的方法org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
 
setup(int) - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelector
Initializes the channel selector with the number of output channels.
setup(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
setup() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
 
setup() - 类 中的方法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>) - 类 中的方法org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - 类 中的方法org.apache.flink.runtime.operators.AllGroupCombineDriver
 
setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.AllGroupReduceDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - 类 中的方法org.apache.flink.runtime.operators.AllReduceDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
setup(TaskConfig, String, Collector<OT>, AbstractInvokable, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.CoGroupDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.CoGroupRawDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
setup(TaskContext<CrossFunction<T1, T2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.CrossDriver
 
setup(TaskContext<S, OT>) - 接口 中的方法org.apache.flink.runtime.operators.Driver
 
setup(TaskContext<FlatMapFunction<IT, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.FlatMapDriver
 
setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - 类 中的方法org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.GroupReduceDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.JoinDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
setup(TaskContext<MapFunction<IT, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.MapDriver
 
setup(TaskContext<MapPartitionFunction<IT, OT>, OT>) - 类 中的方法org.apache.flink.runtime.operators.MapPartitionDriver
 
setup(AbstractInvokable) - 类 中的方法org.apache.flink.runtime.operators.NoOpChainedDriver
 
setup(TaskContext<AbstractRichFunction, T>) - 类 中的方法org.apache.flink.runtime.operators.NoOpDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - 类 中的方法org.apache.flink.runtime.operators.ReduceCombineDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - 类 中的方法org.apache.flink.runtime.operators.ReduceDriver
 
setup(int) - 类 中的方法org.apache.flink.runtime.operators.shipping.OutputEmitter
 
setup(TaskContext<Function, T>) - 类 中的方法org.apache.flink.runtime.operators.UnionWithTempOperator
 
setupInputGate(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
setupPartition(ResultPartition) - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
setUseLargeRecordHandler(boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setUserArtifactBlobKey(String, PermanentBlobKey) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
setValue(byte[]) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
setWaitForSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
setWebUIPort(int) - 类 中的方法org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
SetWorkerPoolSize - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the resource master actor to adjust the designated number of workers it maintains.
SetWorkerPoolSize(int) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
setWritePosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
SharedSlot - org.apache.flink.runtime.instance中的类
This class represents a shared slot.
SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment) - 类 的构造器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) - 类 的构造器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) - 类 的构造器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 - 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() - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistry
Default uses direct executor to delete unreferenced state
SharedStateRegistry(Executor) - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistry
 
SharedStateRegistry.Result - org.apache.flink.runtime.state中的类
The result of an attempt to (un)/reference state
SharedStateRegistryFactory - org.apache.flink.runtime.state中的接口
Simple factory to produce SharedStateRegistry objects.
SharedStateRegistryKey - 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) - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistryKey
 
SharedStateRegistryKey(String) - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistryKey
 
ShipStrategyType - org.apache.flink.runtime.operators.shipping中的枚举
Enumeration defining the different shipping types of the output, such as local forward, re-partitioning by hash, or re-partitioning by range.
shouldExitJvmOnOutOfMemoryError() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
shouldExitJvmOnOutOfMemoryError() - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Checks whether the TaskManager should exit the JVM when the task thread throws an OutOfMemoryError.
shouldIncludeFinished() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldIncludeRunning() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldInterruptOnCancel() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Checks whether the task should be interrupted during cancellation.
shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Shuts down the checkpoint coordinator.
shutdown(JobStatus) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Shuts the CheckpointIDCounter service.
shutdown(JobStatus) - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Shuts down the store.
shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
shutdown() - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
shutdown() - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Shutdown method which may release created class loaders.
shutdown() - 类 中的方法org.apache.flink.runtime.filecache.FileCache
Shuts down the file cache by cancelling all.
shutdown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
Shuts down this leader election service.
shutdown() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
shutdown() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
 
shutdown() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
Close method, marks the I/O manager as closed and removed all temporary files.
shutdown() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Close method.
shutdown() - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
 
shutdown() - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
shutdown() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
shutdown() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
Tries to shut down all network I/O components.
shutdown() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
shutdown() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Shuts the scheduler down.
shutdown() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
Shutdown the JobMaster services.
shutdown() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Shuts the memory manager down, trying to release all the memory it managed.
shutdown() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
Shuts down this registry and the associated MetricReporter.
shutdown() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
shutdown() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Forces an immediate shutdown of the thread.
shutdown() - 接口 中的方法org.apache.flink.runtime.query.KvStateServer
Shuts down the server and all related thread pools.
shutDown() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Shuts the BackPressureStatsTracker down.
shutDown() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Shuts down the stats tracker.
shutDown() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Shuts down the coordinator.
shutdown(Time) - 类 中的方法org.apache.flink.runtime.rest.RestClient
 
shutdown() - 类 中的方法org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
shutDown() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
Shuts the TaskExecutor services down.
shutdown() - 类 中的方法org.apache.flink.runtime.taskmanager.MemoryLogger
 
shutDownCluster() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
shutDownCluster() - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
 
ShutdownClusterAfterJob - org.apache.flink.runtime.clusterframework.messages中的类
Message sent to the cluster framework master to signal it that the cluster should be shut down upon completion of a certain job identified by a job id.
ShutdownClusterAfterJob(JobID) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
ShutdownHandler - 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>) - 类 的构造器org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
 
ShutdownHeaders - org.apache.flink.runtime.rest.messages.cluster中的类
Message headers for ShutdownHandler.
ShutdownHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
 
shutdownHook - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Shutdown hook thread to ensure deletion of the local storage directory.
shutDownInternal() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
 
shutDownInternal() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
Stops this REST server endpoint.
shutDownInternal() - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
shutdownRequested - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
 
SignalHandler - org.apache.flink.runtime.util中的类
This signal handler / signal logger is based on Apache Hadoop's org.apache.hadoop.util.SignalLogger.
SignalHandler() - 类 的构造器org.apache.flink.runtime.util.SignalHandler
 
signalTermination() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
SignatureVisitorImpl(int) - 类 的构造器org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
SimpleCloseableInputProvider<E> - org.apache.flink.runtime.operators.util中的类
A simple iterator provider that returns a supplied iterator and does nothing when closed.
SimpleCloseableInputProvider(MutableObjectIterator<E>) - 类 的构造器org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
Creates a new simple input provider that will return the given iterator.
SimpleCollectingOutputView - 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) - 类 的构造器org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
SimpleIterable(IN, MutableObjectIterator<IN>) - 类 的构造器org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
 
SimpleIterator(IN, MutableObjectIterator<IN>) - 类 的构造器org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
SimpleSlot - 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) - 类 的构造器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) - 类 的构造器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) - 类 的构造器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) - 类 的构造器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 - org.apache.flink.runtime.instance中的类
Simple implementation of the SlotContext interface for the legacy code.
SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway) - 类 的构造器org.apache.flink.runtime.instance.SimpleSlotContext
 
SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway, ResourceProfile) - 类 的构造器org.apache.flink.runtime.instance.SimpleSlotContext
 
SimpleStateEntry(K, N, S) - 类 的构造器org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
 
SingleElementIterator<E> - org.apache.flink.runtime.util中的类
An Iterator that contains only a single element.
SingleElementIterator() - 类 的构造器org.apache.flink.runtime.util.SingleElementIterator
 
SingleInputGate - org.apache.flink.runtime.io.network.partition.consumer中的类
An input gate consumes one or more partitions of a single produced intermediate result.
SingleInputGate(String, JobID, IntermediateDataSetID, ResultPartitionType, int, int, TaskActions, TaskIOMetricGroup, boolean) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
SingleJobSubmittedJobGraphStore - org.apache.flink.runtime.dispatcher中的类
SubmittedJobGraphStore implementation for a single job.
SingleJobSubmittedJobGraphStore(JobGraph) - 类 的构造器org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
SingleLeaderElectionService - org.apache.flink.runtime.highavailability.nonha.leaderelection中的类
An implementation of the LeaderElectionService interface that handles a single leader contender.
SingleLeaderElectionService(Executor, UUID) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
Creates a new leader election service.
SingleLogicalSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
Implementation of the LogicalSlot which is used by the SlotPoolImpl.
SingleLogicalSlot(SlotRequestId, SlotContext, SlotSharingGroupId, Locality, SlotOwner) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
singleton(T) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
SIZE - 类 中的静态变量org.apache.flink.runtime.blob.BlobKey
Size of the internal BLOB key in bytes.
size() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
size() - 接口 中的方法org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Returns the current number of stored ArchivedExecutionGraph.
size() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
size() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
size() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
size() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
size() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
size() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.AvailableSlots
 
size() - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
size() - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
size() - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the number of elements in the sortable.
size() - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
size() - 类 中的方法org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the number of elements currently stored in the PriorityQueue.
size() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
Gets the number of cache entries.
size() - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Returns the number of routes in this router.
size - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
The current size of the priority queue.
size() - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
size() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Returns the total number of entries in this CopyOnWriteStateTable.
size() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
 
size() - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
size() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Returns the total number of entries in this StateTable.
size() - 接口 中的方法org.apache.flink.runtime.state.InternalPriorityQueue
Returns the number of elements in this set.
size() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
 
size() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
size() - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
sizeOfNamespace(Object) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
sizeOfNamespace(Object) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
sizeOfNamespace(Object) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
 
skip(long) - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
skip(long) - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
 
skipBytes(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
skipBytesToRead(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
 
skipBytesToWrite(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
Slot - 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) - 类 的构造器org.apache.flink.runtime.instance.Slot
Base constructor for slots.
Slot(SlotContext, SlotOwner, int, SharedSlot, AbstractID) - 类 的构造器org.apache.flink.runtime.instance.Slot
Base constructor for slots.
SlotActions - org.apache.flink.runtime.taskexecutor.slot中的接口
Interface to trigger slot actions from within the TaskSlotTable.
SlotAllocationException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception indicating that the slot allocation on the task manager failed.
SlotAllocationException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAllocationException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAllocationException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAndLocality - org.apache.flink.runtime.jobmaster.slotpool中的类
A combination of a AllocatedSlot and a Locality.
SlotAndLocality(PhysicalSlot, Locality) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
SlotAvailabilityListener - org.apache.flink.runtime.jobmanager.scheduler中的接口
A SlotAvailabilityListener can be notified when new Slots become available on an Instance.
SlotContext - org.apache.flink.runtime.jobmaster中的接口
Interface for the context of a LogicalSlot.
SlotID - org.apache.flink.runtime.clusterframework.types中的类
Unique identifier for a slot on a TaskManager.
SlotID(ResourceID, int) - 类 的构造器org.apache.flink.runtime.clusterframework.types.SlotID
 
SlotInfo - org.apache.flink.runtime.jobmaster中的接口
Interface that provides basic information in the context of a slot.
SlotManager - org.apache.flink.runtime.resourcemanager.slotmanager中的类
The slot manager is responsible for maintaining a view on all registered task manager slots, their allocation and all pending slot requests.
SlotManager(ScheduledExecutor, Time, Time, Time, boolean) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
SlotManagerConfiguration - org.apache.flink.runtime.resourcemanager.slotmanager中的类
Configuration for the SlotManager.
SlotManagerConfiguration(Time, Time, Time, boolean) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
SlotManagerException - org.apache.flink.runtime.resourcemanager.slotmanager中的异常错误
 
SlotManagerException(String) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
 
SlotManagerException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
 
SlotNotActiveException - org.apache.flink.runtime.taskexecutor.slot中的异常错误
Exception indicating that the given TaskSlot was not in state active.
SlotNotActiveException(JobID, AllocationID) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException
 
SlotNotFoundException - org.apache.flink.runtime.taskexecutor.slot中的异常错误
Exception indicating that a TaskSlot could not be found.
SlotNotFoundException(AllocationID) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
 
SlotNotFoundException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
 
SlotOccupiedException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception which signals that a slot is already occupied by the given AllocationID.
SlotOccupiedException(String, AllocationID, JobID) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
SlotOffer - org.apache.flink.runtime.taskexecutor.slot中的类
Describe the slot offering to job manager provided by task manager.
SlotOffer(AllocationID, int, ResourceProfile) - 类 的构造器org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
SlotOwner - org.apache.flink.runtime.jobmaster中的接口
Interface for components that hold slots and to which slots get released / recycled.
SlotPool - org.apache.flink.runtime.jobmaster.slotpool中的接口
The Interface of a slot pool that manages slots.
SlotPoolFactory - org.apache.flink.runtime.jobmaster.slotpool中的接口
Factory interface for SlotPool.
SlotPoolImpl - org.apache.flink.runtime.jobmaster.slotpool中的类
The slot pool serves slot request issued by ExecutionGraph.
SlotPoolImpl(JobID) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
SlotPoolImpl(JobID, Clock, Time, Time) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
SlotPoolImpl.AvailableSlots - org.apache.flink.runtime.jobmaster.slotpool中的类
Organize all available slots from different points of view.
SlotProfile - 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>) - 类 的构造器org.apache.flink.runtime.clusterframework.types.SlotProfile
 
SlotProfile(ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>, Set<AllocationID>) - 类 的构造器org.apache.flink.runtime.clusterframework.types.SlotProfile
 
SlotProvider - org.apache.flink.runtime.jobmaster.slotpool中的接口
The slot provider is responsible for preparing slots for ready-to-run tasks.
SlotReport - 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() - 类 的构造器org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotReport(SlotStatus) - 类 的构造器org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotReport(Collection<SlotStatus>) - 类 的构造器org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotRequest - 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) - 类 的构造器org.apache.flink.runtime.resourcemanager.SlotRequest
 
SlotRequestId - 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) - 类 的构造器org.apache.flink.runtime.jobmaster.SlotRequestId
 
SlotRequestId() - 类 的构造器org.apache.flink.runtime.jobmaster.SlotRequestId
 
SlotSelectionStrategy - org.apache.flink.runtime.jobmaster.slotpool中的接口
Interface for slot selection strategies to be used in the Scheduler.
SlotSelectionStrategy.SlotInfoAndLocality - org.apache.flink.runtime.jobmaster.slotpool中的类
This class is a value type that combines a SlotInfo with a Locality hint.
SlotSharingGroup - 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() - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
SlotSharingGroup(JobVertexID...) - 类 的构造器org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
SlotSharingGroupAssignment - org.apache.flink.runtime.instance中的类
The SlotSharingGroupAssignment manages a set of shared slots, which are shared between tasks of a SlotSharingGroup.
SlotSharingGroupAssignment() - 类 的构造器org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
SlotSharingGroupId - org.apache.flink.runtime.instance中的类
 
SlotSharingGroupId(long, long) - 类 的构造器org.apache.flink.runtime.instance.SlotSharingGroupId
 
SlotSharingGroupId() - 类 的构造器org.apache.flink.runtime.instance.SlotSharingGroupId
 
SlotSharingManager - org.apache.flink.runtime.jobmaster.slotpool中的类
Manager which is responsible for slot sharing.
SlotSharingManager.MultiTaskSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
SlotSharingManager.TaskSlot implementation which can have multiple other task slots assigned as children.
SlotSharingManager.SingleTaskSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
SlotSharingManager.TaskSlot implementation which harbours a LogicalSlot.
SlotSharingManager.TaskSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
Base class for all task slots.
SlotStatus - org.apache.flink.runtime.taskexecutor中的类
This describes the slot current status which located in TaskManager.
SlotStatus(SlotID, ResourceProfile) - 类 的构造器org.apache.flink.runtime.taskexecutor.SlotStatus
 
SlotStatus(SlotID, ResourceProfile, JobID, AllocationID) - 类 的构造器org.apache.flink.runtime.taskexecutor.SlotStatus
 
SnappyStreamCompressionDecorator - org.apache.flink.runtime.state中的类
This implementation decorates the stream with snappy compression.
SnappyStreamCompressionDecorator() - 类 的构造器org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
snapshot() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
snapshot() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
snapshot() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
snapshot() - 类 中的方法org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
snapshot() - 类 中的方法org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - 接口 中的方法org.apache.flink.runtime.state.SnapshotStrategy
Operation that writes a snapshot into a stream that is provided by the given CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to the snapshot.
snapshotCloseableRegistry - 类 中的变量org.apache.flink.runtime.state.AsyncSnapshotCallable
Registers streams that can block in I/O during snapshot.
snapshotConfiguration() - 类 中的方法org.apache.flink.runtime.state.ArrayListSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
snapshotConfiguration() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceSerializer
 
SnapshotDirectory - org.apache.flink.runtime.state中的类
This class represents a directory that is the target for a state snapshot.
SnapshotResult<T extends StateObject> - 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.
SnapshotStrategy<S extends StateObject> - org.apache.flink.runtime.state中的接口
Interface for different snapshot approaches in state backends.
SolutionSetBroker - org.apache.flink.runtime.iterative.concurrent中的类
Used to hand over the hash-join from the iteration head to the solution-set match.
SolutionSetFastUpdateOutputCollector<T> - org.apache.flink.runtime.iterative.io中的类
A Collector to update the solution set of a workset iteration.
SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
SolutionSetObjectsUpdateOutputCollector<T> - org.apache.flink.runtime.iterative.io中的类
A Collector to update the solution set of a workset iteration.
SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>, Collector<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
SolutionSetUpdateBarrier - org.apache.flink.runtime.iterative.concurrent中的类
Resettable barrier to synchronize the IterationHeadTask and the IterationTailTask in case of iterations that contain a separate solution set tail.
SolutionSetUpdateBarrier() - 类 的构造器org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
 
SolutionSetUpdateBarrierBroker - org.apache.flink.runtime.iterative.concurrent中的类
SolutionSetUpdateOutputCollector<T> - org.apache.flink.runtime.iterative.io中的类
A Collector to update the solution set of a workset iteration.
SolutionSetUpdateOutputCollector(CompactingHashTable<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
SolutionSetUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
sort(IndexedSortable, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.HeapSort
 
sort(IndexedSortable) - 类 中的方法org.apache.flink.runtime.operators.sort.HeapSort
 
sort(IndexedSortable, int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSorter
Sort the items accessed through the given IndexedSortable over the given range of logical indices.
sort(IndexedSortable) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSorter
 
sort(IndexedSortable, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.QuickSort
Sort the given range of items using quick sort.
sort(IndexedSortable) - 类 中的方法org.apache.flink.runtime.operators.sort.QuickSort
 
Sorter<E> - 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) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Creates a new sorting thread.
sortReadMemory - 类 中的变量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 - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
source - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
SpanningRecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.serialization中的类
Record serializer which serializes the complete record to an intermediate data serialization buffer and copies this buffer to target buffers one-by-one using SpanningRecordSerializer.copyToBufferBuilder(BufferBuilder).
SpanningRecordSerializer() - 类 的构造器org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
spillHeadCopy - 类 中的变量org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
SpillingAdaptiveSpanningRecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.serialization中的类
 
SpillingAdaptiveSpanningRecordDeserializer(String[]) - 类 的构造器org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
SpillingBuffer - 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) - 类 的构造器org.apache.flink.runtime.io.disk.SpillingBuffer
 
spillingMarker() - 类 中的静态方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for signal beginning of spilling.
SpillingResettableIterator<T> - org.apache.flink.runtime.operators.resettable中的类
Implementation of a resettable iterator.
SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - 类 的构造器org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
SpillingResettableMutableObjectIterator<T> - org.apache.flink.runtime.operators.resettable中的类
Implementation of a resettable iterator.
SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - 类 的构造器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) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Creates the spilling thread.
spillPartition(List<MemorySegment>, IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - 类 中的方法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() - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable
Selects a partition and spills it.
SSLHandlerFactory - org.apache.flink.runtime.io.network.netty中的类
Creates and configures SslHandler instances.
SSLHandlerFactory(SSLContext, String[], String[], boolean, boolean, int, int) - 类 的构造器org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
Create a new SslHandler factory.
SSLStoreOverlay - org.apache.flink.runtime.clusterframework.overlays中的类
Overlays an SSL keystore/truststore into a container.
SSLStoreOverlay(File, File) - 类 的构造器org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
SSLStoreOverlay.Builder - org.apache.flink.runtime.clusterframework.overlays中的类
A builder for the Krb5ConfOverlay.
SSLUtils - org.apache.flink.runtime.net中的类
Common utilities to manage SSL transport settings.
SSLUtils() - 类 的构造器org.apache.flink.runtime.net.SSLUtils
 
StackTrace - org.apache.flink.runtime.messages中的类
 
StackTrace(InstanceID, String) - 类 的构造器org.apache.flink.runtime.messages.StackTrace
 
StackTraceSample - 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[]>>) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Creates a stack trace sample.
StackTraceSampleCoordinator - org.apache.flink.runtime.rest.handler.legacy.backpressure中的类
A coordinator for triggering and collecting stack traces of running tasks.
StackTraceSampleCoordinator(Executor, long) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Creates a new coordinator for the job.
StackTraceSampleResponse - org.apache.flink.runtime.messages中的类
Response to the TriggerStackTraceSample message.
StackTraceSampleResponse(int, ExecutionAttemptID, List<StackTraceElement[]>) - 类 的构造器org.apache.flink.runtime.messages.StackTraceSampleResponse
 
StandaloneCheckpointIDCounter - org.apache.flink.runtime.checkpoint中的类
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneCheckpointIDCounter() - 类 的构造器org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
StandaloneCheckpointRecoveryFactory - org.apache.flink.runtime.checkpoint中的类
StandaloneCheckpointRecoveryFactory() - 类 的构造器org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
StandaloneCompletedCheckpointStore - org.apache.flink.runtime.checkpoint中的类
StandaloneCompletedCheckpointStore(int) - 类 的构造器org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
StandaloneDispatcher - 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) - 类 的构造器org.apache.flink.runtime.dispatcher.StandaloneDispatcher
 
StandaloneHaServices - org.apache.flink.runtime.highavailability.nonha.standalone中的类
An implementation of the HighAvailabilityServices for the non-high-availability case.
StandaloneHaServices(String, String, String, String) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
Creates a new services class for the fix pre-defined leaders.
StandaloneLeaderElectionService - org.apache.flink.runtime.leaderelection中的类
Standalone implementation of the LeaderElectionService interface.
StandaloneLeaderElectionService() - 类 的构造器org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
StandaloneLeaderRetrievalService - org.apache.flink.runtime.leaderretrieval中的类
Standalone implementation of the LeaderRetrievalService.
StandaloneLeaderRetrievalService(String) - 类 的构造器org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
StandaloneLeaderRetrievalService(String, UUID) - 类 的构造器org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
Creates a StandaloneLeaderRetrievalService with the given leader address.
StandaloneResourceManager - org.apache.flink.runtime.resourcemanager中的类
A standalone implementation of the resource manager.
StandaloneResourceManager(RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup) - 类 的构造器org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
StandaloneResourceManagerFactory - org.apache.flink.runtime.resourcemanager中的枚举
StandaloneRunningJobsRegistry - org.apache.flink.runtime.highavailability.nonha.standalone中的类
A registry for running jobs, not-highly available.
StandaloneRunningJobsRegistry() - 类 的构造器org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
StandaloneSessionClusterEntrypoint - org.apache.flink.runtime.entrypoint中的类
Entry point for the standalone session cluster.
StandaloneSessionClusterEntrypoint(Configuration) - 类 的构造器org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
 
StandaloneSubmittedJobGraphStore - org.apache.flink.runtime.jobmanager中的类
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneSubmittedJobGraphStore() - 类 的构造器org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
StandaloneUtils - org.apache.flink.runtime.util中的类
Utility class to work with Flink standalone mode.
start() - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Starts the CheckpointIDCounter service down.
start() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
start() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
start(ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
start(LeaderContender) - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
start(ResultPartitionProvider, TaskEventDispatcher) - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
start() - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Starts the SubmittedJobGraphStore service.
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
start() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
 
start(JobMasterId) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
Start the rpc service and begin to run the job.
start(JobMasterId) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterService
Start the JobMaster service with the given JobMasterId.
start(ComponentMainThreadExecutor) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.Scheduler
Start the scheduler by initializing the main thread executor.
start(ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
 
start(JobMasterId, String, ComponentMainThreadExecutor) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
start(JobMasterId, String, ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
Start the slot pool to accept RPC calls.
start(LeaderContender) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderElectionService
Starts the leader election service.
start(LeaderContender) - 类 中的方法org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
start(LeaderContender) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
start(LeaderRetrievalListener) - 接口 中的方法org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
Starts the leader retrieval service with the given listener to listen for new leaders.
start(LeaderRetrievalListener) - 类 中的方法org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
start(LeaderRetrievalListener) - 类 中的方法org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
start(LeaderRetrievalListener) - 类 中的方法org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
start() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
Starts the mini cluster, based on the configured properties.
start() - 接口 中的方法org.apache.flink.runtime.query.KvStateServer
Starts the server.
start() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
start(JobLeaderIdActions) - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Start the service with the given job leader actions.
start(ResourceManagerId, Executor, ResourceActions) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Starts the slot manager with the given leader id and resource manager actions.
start() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
Starts this REST server endpoint.
start() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Starts the rpc endpoint.
start() - 接口 中的方法org.apache.flink.runtime.rpc.StartStoppable
Starts the processing of remote procedure calls.
start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Start the job leader service with the given services.
start(SlotActions) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Start the task slot table with the given slot actions.
start(TimeoutListener<K>) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
 
start() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
start() - 接口 中的方法org.apache.flink.runtime.webmonitor.WebMonitor
Starts the web monitor.
start() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
start() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
startActorSystem(Configuration, String, String, Logger) - 类 中的静态方法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) - 类 中的静态方法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) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an ActorSystem with the given configuration listening at the address/ports.
startActorSystem(Configuration, String, int, Logger) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an Actor System at a specific port.
startActorSystem(Configuration, String, int, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an Actor System at a specific port.
startActorSystem(Configuration, String, String, int, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an Actor System at a specific port.
startCheckpointScheduler() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
startCluster() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
startCuratorFramework(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Starts a CuratorFramework instance and connects it to the given ZooKeeper quorum.
startIfConfigured(Logger, Configuration, ActorSystem) - 类 中的静态方法org.apache.flink.runtime.taskmanager.MemoryLogger
 
startInternal() - 类 中的方法org.apache.flink.runtime.rest.RestServerEndpoint
Hook to start sub class specific services.
startInternal() - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
startMetricQueryService(ActorSystem, ResourceID, long) - 类 中的静态方法org.apache.flink.runtime.metrics.dump.MetricQueryService
Starts the MetricQueryService actor in the given actor system.
startMetricsActorSystem(Configuration, String, Logger) - 类 中的静态方法org.apache.flink.runtime.metrics.util.MetricUtils
 
startNewKeyGroup(int) - 类 中的方法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() - 类 中的方法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) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Allocates a resource using the resource profile.
startNewWorker(ResourceProfile) - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
startNextSuperstep() - 类 中的方法org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
startNextSuperstep() - 接口 中的方法org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
startQueryService(ActorSystem, ResourceID) - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
Initializes the MetricQueryService.
startReading() - 类 中的方法org.apache.flink.runtime.operators.TempBarrier
 
startRegistration() - 类 中的方法org.apache.flink.runtime.registration.RetryingRegistration
This method resolves the target address to a callable gateway and starts the registration after that.
startServer(C) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
startServer(C) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
StartStoppable - 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) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
startTaskThread() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Starts the task's thread.
startThreads() - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Starts all the threads that are used by this sort-merger.
STARTUP_FAILURE_RETURN_CODE - 类 中的静态变量org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
state - 类 中的变量org.apache.flink.runtime.state.SnapshotDirectory
This reference tracks the lifecycle state of the snapshot directory.
StateAssignmentOperation - 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) - 类 的构造器org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
StateBackend - 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> - org.apache.flink.runtime.state中的接口
A mutable builder to build a state backend instance.
StateBackendFactory<T extends StateBackend> - org.apache.flink.runtime.state中的接口
A factory to create a specific state backend.
StateBackendLoader - org.apache.flink.runtime.state中的类
This class contains utility methods to load state backends from configurations.
StateEntry<K,N,S> - org.apache.flink.runtime.state中的接口
Interface of entries in a state backend.
StateEntry.SimpleStateEntry<K,N,S> - org.apache.flink.runtime.state中的类
 
StateHandleID - org.apache.flink.runtime.state中的类
Unique ID that allows for logical comparison between state handles.
StateHandleID(String) - 类 的构造器org.apache.flink.runtime.state.StateHandleID
 
StateInitializationContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which operators can initialize by registering to managed state (i.e. state that is managed by state backends) or iterating over streams of state partitions written as raw state in a previous snapshot.
StateInitializationContextImpl - org.apache.flink.runtime.state中的类
Default implementation of StateInitializationContext.
StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider>, Iterable<StatePartitionStreamProvider>) - 类 的构造器org.apache.flink.runtime.state.StateInitializationContextImpl
 
stateLock - 类 中的变量org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The lock to synchronize state changes (open / close) on
StateMetaInfo(long[], OperatorStateHandle.Mode) - 类 的构造器org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
StateMetaInfoReader - org.apache.flink.runtime.state.metainfo中的接口
Functional interface to read StateMetaInfoSnapshot.
StateMetaInfoSnapshot - 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<?>>) - 类 的构造器org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
 
StateMetaInfoSnapshot(String, StateMetaInfoSnapshot.BackendStateType, Map<String, String>, Map<String, TypeSerializerSnapshot<?>>, Map<String, TypeSerializer<?>>) - 类 的构造器org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
TODO this variant, which requires providing the serializers, TODO should actually be removed, leaving only StateMetaInfoSnapshot.StateMetaInfoSnapshot(String, BackendStateType, Map, Map).
StateMetaInfoSnapshot.BackendStateType - org.apache.flink.runtime.state.metainfo中的枚举
Enum that defines the different types of state that live in Flink backends.
StateMetaInfoSnapshot.CommonOptionsKeys - org.apache.flink.runtime.state.metainfo中的枚举
Predefined keys for the most common options in the meta info.
StateMetaInfoSnapshot.CommonSerializerKeys - org.apache.flink.runtime.state.metainfo中的枚举
Predefined keys for the most common serializer types in the meta info.
StateMetaInfoSnapshotReadersWriters - org.apache.flink.runtime.state.metainfo中的类
Static factory that gives out the write and readers for different versions of StateMetaInfoSnapshot.
StateMetaInfoSnapshotReadersWriters.StateTypeHint - org.apache.flink.runtime.state.metainfo中的枚举
Enum for backwards compatibility.
StateMetaInfoWriter - org.apache.flink.runtime.state.metainfo中的接口
Functional interface to write StateMetaInfoSnapshot.
StateObject - org.apache.flink.runtime.state中的接口
Base of all handles that represent checkpointed state in some form.
StateObjectCollection<T extends StateObject> - org.apache.flink.runtime.checkpoint中的类
This class represents a generic collection for StateObjects.
StateObjectCollection() - 类 的构造器org.apache.flink.runtime.checkpoint.StateObjectCollection
Creates a new StateObjectCollection that is backed by an ArrayList.
StateObjectCollection(Collection<T>) - 类 的构造器org.apache.flink.runtime.checkpoint.StateObjectCollection
Creates a new StateObjectCollection wraps the given collection and delegates to it.
StatePartitionStreamProvider - 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) - 类 的构造器org.apache.flink.runtime.state.StatePartitionStreamProvider
 
StatePartitionStreamProvider(InputStream) - 类 的构造器org.apache.flink.runtime.state.StatePartitionStreamProvider
 
StateSerializerProvider<T> - 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() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Creates a snapshot of this CopyOnWriteStateTable, to be written in checkpointing.
stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
 
stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
StateSnapshot - org.apache.flink.runtime.state中的接口
General interface for state snapshots that should be written partitioned by key-groups.
stateSnapshot() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotRestore
Returns a snapshot of the state.
StateSnapshot.StateKeyGroupWriter - org.apache.flink.runtime.state中的接口
Interface for writing a snapshot that is partitioned into key-groups.
StateSnapshotContext - org.apache.flink.runtime.state中的接口
This interface provides a context in which operators that use managed (i.e. state that is managed by state backends) or raw (i.e. the operator can write it's state streams) state can perform a snapshot.
StateSnapshotContextSynchronousImpl - org.apache.flink.runtime.state中的类
This class is a default implementation for StateSnapshotContext.
StateSnapshotContextSynchronousImpl(long, long) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
StateSnapshotContextSynchronousImpl(long, long, CheckpointStreamFactory, KeyGroupRange, CloseableRegistry) - 类 的构造器org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
StateSnapshotKeyGroupReader - org.apache.flink.runtime.state中的接口
Interface for state de-serialization into StateTables by key-group.
StateSnapshotRestore - org.apache.flink.runtime.state中的接口
Interface to deal with state snapshot and restore of state.
StateSnapshotTransformer<T> - org.apache.flink.runtime.state中的接口
Transformer of state values which are included or skipped in the snapshot.
StateSnapshotTransformer.CollectionStateSnapshotTransformer<T> - org.apache.flink.runtime.state中的接口
Collection state specific transformer which says how to transform entries of the collection.
StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy - org.apache.flink.runtime.state中的枚举
 
StateSnapshotTransformer.StateSnapshotTransformFactory<T> - org.apache.flink.runtime.state中的接口
This factory creates state transformers depending on the form of values to transform.
StateSnapshotTransformers - org.apache.flink.runtime.state中的类
Collection of common state snapshot transformers and their factories.
StateSnapshotTransformers() - 类 的构造器org.apache.flink.runtime.state.StateSnapshotTransformers
 
StateSnapshotTransformers.ListStateSnapshotTransformer<T> - org.apache.flink.runtime.state中的类
General implementation of list state transformer.
StateSnapshotTransformers.ListStateSnapshotTransformFactory<T> - org.apache.flink.runtime.state中的类
 
StateSnapshotTransformers.MapStateSnapshotTransformer<K,V> - org.apache.flink.runtime.state中的类
General implementation of map state transformer.
StateSnapshotTransformers.MapStateSnapshotTransformFactory<K,V> - org.apache.flink.runtime.state中的类
 
StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor<S,T> - org.apache.flink.runtime.state中的类
 
stateTable - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapState
Map containing the actual key/value pairs.
StateTable<K,N,S> - org.apache.flink.runtime.state.heap中的类
Base class for state tables.
StateTable(InternalKeyContext<K>, RegisteredKeyValueStateBackendMetaInfo<N, S>) - 类 的构造器org.apache.flink.runtime.state.heap.StateTable
 
StateTransformationFunction<S,T> - org.apache.flink.runtime.state中的接口
Interface for a binary function that is used for push-down of state transformation into state backends.
StateUtil - org.apache.flink.runtime.state中的类
Helpers for StateObject related code.
StaticFileServerHandler<T extends RestfulGateway> - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
 
StatusHandler(GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, AsynchronousOperationResult<V>, M>) - 类 的构造器org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
 
StatusListenerMessenger - org.apache.flink.runtime.executiongraph中的类
A JobStatusListener and ExecutionStatusListener that sends an actor message for each status change.
StatusListenerMessenger(ActorRef, UUID) - 类 的构造器org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
stddev - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
stdOutFile - 类 中的变量org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
StdoutFileHandlerSpecification - org.apache.flink.runtime.rest.handler.legacy.files中的类
Rest handler specification for the stdout file of the main cluster component.
stop() - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
stop() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Sends stop RPC call.
stop() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
stop() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
stop() - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManager
Stops the heartbeat manager.
stop() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
stop() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
stop() - 接口 中的方法org.apache.flink.runtime.jobgraph.tasks.StoppableTask
Called on STOP signal.
stop() - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
stop() - 接口 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Stops the SubmittedJobGraphStore service.
stop() - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
stop(Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
stop(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Cancel the currently executed job.
stop() - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderElectionService
Stops the leader election service.
stop() - 类 中的方法org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
stop() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
stop() - 接口 中的方法org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
Stops the leader retrieval service.
stop() - 类 中的方法org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
stop() - 类 中的方法org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
stop() - 类 中的方法org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
stop() - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop the service.
stop() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Stops the rpc endpoint.
stop() - 接口 中的方法org.apache.flink.runtime.rpc.StartStoppable
Stops the processing of remote procedure calls.
stop() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
Stop the job leader services.
stop() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Stop the task slot table.
stop() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
 
stop() - 接口 中的方法org.apache.flink.runtime.webmonitor.WebMonitor
Stops the web server.
stopActor(AkkaActorGateway) - 类 中的静态方法org.apache.flink.runtime.akka.ActorUtils
 
stopActor(ActorRef) - 类 中的静态方法org.apache.flink.runtime.akka.ActorUtils
 
stopCheckpointScheduler() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
StopCluster - org.apache.flink.runtime.clusterframework.messages中的类
Generic message to signal the cluster framework to shut the cluster down.
StopCluster(ApplicationStatus, String) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.StopCluster
 
stopClusterServices(boolean) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
StopClusterSuccessful - org.apache.flink.runtime.clusterframework.messages中的类
Generic message to signal the cluster listener that the cluster has been shut down.
stopExecution() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Stops the executing task by calling StoppableTask.stop().
stopJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
stopJob(JobID) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
stopJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Stop the given job.
StoppableTask - org.apache.flink.runtime.jobgraph.tasks中的接口
Implemented by tasks that can receive STOP signal.
stopped - 类 中的变量org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
Running state of the heartbeat manager.
StoppingException - org.apache.flink.runtime中的异常错误
Indicates that a job is not stoppable.
StoppingException(String) - 异常错误 的构造器org.apache.flink.runtime.StoppingException
 
StoppingException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.StoppingException
 
StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy - org.apache.flink.runtime.akka中的类
Stopping supervisor strategy which logs ActorKilledException only on debug log level.
StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy() - 类 的构造器org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
 
stopServer(RpcServer) - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopServer(RpcServer) - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Stop the underlying rpc server of the provided self gateway.
stopService() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopService() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
Trigger the asynchronous stopping of the RpcService.
stopTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
stopTask(ExecutionAttemptID, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Stop the given task.
stopTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
stopTask(ExecutionAttemptID, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
stopTask(ExecutionAttemptID, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Stop the given task.
stopWorker(WorkerType) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Stops the given worker.
stopWorker(ResourceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
storageDir - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Root directory for local file storage.
store(T) - 类 中的方法org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
store(T) - 接口 中的方法org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper
Stores the given state and returns a state handle to it.
storeCheckpointMetadata(T, OutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
storeCheckpointMetadata(T, DataOutputStream) - 类 中的静态方法org.apache.flink.runtime.checkpoint.Checkpoints
 
storeLocalState(long, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
 
storeLocalState(long, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.state.TaskLocalStateStore
Stores the local state for the given checkpoint id.
storeLocalState(long, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
StreamCompressionDecorator - org.apache.flink.runtime.state中的类
Implementations of this interface decorate streams with a compression scheme.
StreamCompressionDecorator() - 类 的构造器org.apache.flink.runtime.state.StreamCompressionDecorator
 
StreamStateHandle - org.apache.flink.runtime.state中的接口
A StateObject that represents state that was written to a stream.
StringifiedAccumulatorResult - org.apache.flink.runtime.accumulators中的类
Container class that transports the result of an accumulator as set of strings.
StringifiedAccumulatorResult(String, String, String) - 类 的构造器org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
stringifyAccumulatorResults(Map<String, OptionalFailure<Accumulator<?, ?>>>) - 类 中的静态方法org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
Flatten a map of accumulator names to Accumulator instances into an array of StringifiedAccumulatorResult values.
stub - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The instantiated user code of this task's main operator (driver).
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Gets all component metric groups that are contained in this component metric group.
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
subComponents() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
submitJob(JobGraph, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
submitJob(JobGraph, Time) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherGateway
Submit a job to the dispatcher.
submitJob(JobGraph, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
 
submitJob(JobGraph) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
submitTask(TaskDeploymentDescriptor, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
submitTask(TaskDeploymentDescriptor, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Submit a task to the task manager.
submitTask(TaskDeploymentDescriptor, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Submit a Task to the TaskExecutor.
SubmittedJobGraph - org.apache.flink.runtime.jobmanager中的类
A recoverable JobGraph.
SubmittedJobGraph(JobGraph) - 类 的构造器org.apache.flink.runtime.jobmanager.SubmittedJobGraph
SubmittedJobGraphStore - org.apache.flink.runtime.jobmanager中的接口
SubmittedJobGraph instances for recovery.
SubmittedJobGraphStore.SubmittedJobGraphListener - org.apache.flink.runtime.jobmanager中的接口
A listener for SubmittedJobGraph instances.
subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - 类 中的方法org.apache.flink.runtime.io.network.api.TaskEventHandler
 
subscribeToEvent(ResultPartitionID, EventListener<TaskEvent>, Class<? extends TaskEvent>) - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
Subscribes a listener to this dispatcher for events on a partition.
substituteDeprecatedConfigKey(Configuration, String, String) - 类 中的静态方法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) - 类 中的静态方法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>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
SubtaskAttemptMessageParameters - org.apache.flink.runtime.rest.messages.job中的类
The type Subtask attempt message parameters.
SubtaskAttemptMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
 
subtaskAttemptPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
 
SubtaskAttemptPathParameter - org.apache.flink.runtime.rest.messages.job中的类
Path parameter identifying subtask attempt.
SubtaskAttemptPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
Instantiates a new Subtask attempt path parameter.
SubtaskBackPressureInfo(int, JobVertexBackPressureInfo.VertexBackPressureLevel, double) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
subtaskBaseDirectory(long) - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state directory for the owning subtask the given checkpoint id w.r.t. our rotation over all available available allocation base directories.
subtaskBaseDirectory(long) - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
SubtaskCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint statistics for a subtask.
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint statistics for a completed subtask checkpoint.
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment - org.apache.flink.runtime.rest.messages.checkpoints中的类
Alignment statistics of the checkpoint.
SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration - org.apache.flink.runtime.rest.messages.checkpoints中的类
Duration of the checkpoint.
SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint statistics for a pending subtask checkpoint.
SubtaskCurrentAttemptDetailsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
 
SubtaskCurrentAttemptDetailsHeaders - org.apache.flink.runtime.rest.messages.job中的类
Message headers for the SubtaskCurrentAttemptDetailsHandler.
SubtaskCurrentAttemptDetailsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
SubtaskExecutionAttemptAccumulatorsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
Instantiates a new Abstract job vertex handler.
SubtaskExecutionAttemptAccumulatorsHeaders - org.apache.flink.runtime.rest.messages.job中的类
SubtaskExecutionAttemptAccumulatorsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
SubtaskExecutionAttemptAccumulatorsInfo - org.apache.flink.runtime.rest.messages.job中的类
SubtaskExecutionAttemptAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
SubtaskExecutionAttemptDetailsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
Instantiates a new subtask execution attempt details handler.
SubtaskExecutionAttemptDetailsHeaders - org.apache.flink.runtime.rest.messages.job中的类
Message headers for the SubtaskExecutionAttemptDetailsHandler.
SubtaskExecutionAttemptDetailsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
SubtaskExecutionAttemptDetailsInfo - org.apache.flink.runtime.rest.messages.job中的类
The sub task execution attempt response.
SubtaskExecutionAttemptDetailsInfo(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
subtaskIndex - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
subtaskIndex - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
subtaskIndex - 类 中的变量org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
subtaskIndex() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
subtaskIndexPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
 
SubtaskIndexPathParameter - org.apache.flink.runtime.rest.messages中的类
Path parameter specifying the index of a subtask.
SubtaskIndexPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
SubtaskMessageParameters - org.apache.flink.runtime.rest.messages.job中的类
Message parameters for subtask REST handlers.
SubtaskMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
 
SubtaskMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Handler that returns subtask metrics.
SubtaskMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
 
SubtaskMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
SubtaskMetricsMessageParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
SubtaskMetricsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
 
SubtasksAllAccumulatorsHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
 
SubtasksAllAccumulatorsHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the SubtasksAllAccumulatorsHandler.
SubtasksAllAccumulatorsInfo - org.apache.flink.runtime.rest.messages.job中的类
Response type of the SubtasksAllAccumulatorsHandler.
SubtasksAllAccumulatorsInfo(JobVertexID, int, Collection<SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
 
SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo - org.apache.flink.runtime.rest.messages.job中的类
Detailed information about subtask accumulators.
SubtasksFilterQueryParameter - org.apache.flink.runtime.rest.messages.job.metrics中的类
MessageQueryParameter for selecting subtasks when aggregating metrics.
subtaskSpecificCheckpointDirectory(long) - 接口 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state directory for the specific operator subtask and the given checkpoint id w.r.t. our rotation over all available root dirs.
subtaskSpecificCheckpointDirectory(long) - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
SubtaskState - 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) - 类 的构造器org.apache.flink.runtime.checkpoint.SubtaskState
 
SubtaskStateStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a single subtask that is part of a checkpoint.
SubtasksTimesHandler - 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) - 类 的构造器org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
 
SubtasksTimesHeaders - org.apache.flink.runtime.rest.messages中的类
Message headers for the SubtasksTimesHandler.
SubtasksTimesHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
SubtasksTimesInfo - org.apache.flink.runtime.rest.messages中的类
Response type of the SubtasksTimesHandler.
SubtasksTimesInfo(String, String, long, List<SubtasksTimesInfo.SubtaskTimeInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
 
SubtasksTimesInfo.SubtaskTimeInfo - org.apache.flink.runtime.rest.messages中的类
Nested class to encapsulate the sub task times info.
SubtaskTimeInfo(int, String, long, Map<ExecutionState, Long>) - 类 的构造器org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
Success() - 类 的构造器org.apache.flink.runtime.registration.RegistrationResponse.Success
 
Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, MinMaxAvgStatistics) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
SuperstepBarrier - org.apache.flink.runtime.iterative.concurrent中的类
A resettable one-shot latch.
SuperstepBarrier(ClassLoader) - 类 的构造器org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
SuperstepKickoffLatch - org.apache.flink.runtime.iterative.concurrent中的类
Latch used to wait for the previous superstep to complete.
SuperstepKickoffLatch() - 类 的构造器org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
SuperstepKickoffLatchBroker - org.apache.flink.runtime.iterative.concurrent中的类
supplyAsync(SupplierWithException<T, ?>, Executor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Returns a future which is completed with the result of the SupplierWithException.
supportsAsynchronousSnapshots() - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
supportsAsynchronousSnapshots() - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
supportsHighlyAvailableStorage() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorage
Checks whether this backend supports highly available storage of data.
supportsHighlyAvailableStorage() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
supportsHighlyAvailableStorage() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
SuppressRestartsException - org.apache.flink.runtime.execution中的异常错误
Exception thrown in order to suppress job restarts.
SuppressRestartsException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.execution.SuppressRestartsException
 
suspend() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
suspend(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Suspends the current ExecutionGraph.
suspend() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
suspend() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
suspend(Exception) - 类 中的方法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) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterService
Suspend the JobMaster service.
suspend() - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
suspend() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
Suspends this pool, meaning it has lost its authority to accept and distribute slots.
suspend() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Suspends the component.
swap(int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
swap(int, int, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
swap(int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Swap items at the given addresses.
swap(int, int, int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
Swap records at the given addresses.
swap(int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
swap(int, int, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
switchBuffers() - 类 中的方法org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
sync() - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
sync() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
sync() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
sync() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
sync() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
SyncEventHandler - 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) - 类 的构造器org.apache.flink.runtime.iterative.task.SyncEventHandler
 
SynchronousBufferFileReader - org.apache.flink.runtime.io.disk.iomanager中的类
A synchronous BufferFileReader implementation.
SynchronousBufferFileReader(FileIOChannel.ID, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
SynchronousChainedCombineDriver<IN,OUT> - org.apache.flink.runtime.operators.chaining中的类
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
SynchronousChainedCombineDriver() - 类 的构造器org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
SynchronousFileIOChannel - org.apache.flink.runtime.io.disk.iomanager中的类
A base class for synchronous readers and writers.
SynchronousFileIOChannel(FileIOChannel.ID, boolean) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
SystemClock - org.apache.flink.runtime.util.clock中的类
A clock that returns the time of the system / process.
SystemResourcesCounter - org.apache.flink.runtime.metrics.util中的类
Daemon thread probing system resources.
SystemResourcesCounter(Time) - 类 的构造器org.apache.flink.runtime.metrics.util.SystemResourcesCounter
 
SystemResourcesMetricsInitializer - org.apache.flink.runtime.metrics.util中的类
Utility class to initialize system resource metrics.
SystemResourcesMetricsInitializer() - 类 的构造器org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
 

T

tagAsEvent() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
Tags this buffer to represent an event.
tagAsEvent() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
tagAsEvent() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
takeNext(BlockingQueue<UnilateralSortMerger.CircularElement<E>>, Queue<UnilateralSortMerger.CircularElement<E>>) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
target() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
 
Task - org.apache.flink.runtime.taskmanager中的类
The Task represents one execution of a parallel subtask on a TaskManager.
Task(JobInformation, TaskInformation, ExecutionAttemptID, AllocationID, int, int, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>, int, MemoryManager, IOManager, NetworkEnvironment, BroadcastVariableManager, TaskStateManager, TaskManagerActions, InputSplitProvider, CheckpointResponder, GlobalAggregateManager, BlobCacheService, LibraryCacheManager, FileCache, TaskManagerRuntimeInfo, TaskMetricGroup, ResultPartitionConsumableNotifier, PartitionProducerStateChecker, Executor) - 类 的构造器org.apache.flink.runtime.taskmanager.Task
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
TASK_MANAGER_NAME - 类 中的静态变量org.apache.flink.runtime.taskexecutor.TaskExecutor
 
TASK_MANAGERS_FIELD_DURATION - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_END_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_HOST - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_METRICS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_START_TIME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_STATUS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_MANAGERS_FIELD_STATUS_COUNTS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TASK_SLOTS_AVAILABLE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
TASK_SLOTS_TOTAL - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
 
TaskActions - org.apache.flink.runtime.taskmanager中的接口
Actions which can be performed on a Task.
TaskCheckpointMessageParameters - org.apache.flink.runtime.rest.messages.checkpoints中的类
Message parameters for subtask related checkpoint message.
TaskCheckpointMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
 
TaskCheckpointStatisticDetailsHandler - org.apache.flink.runtime.rest.handler.job.checkpoints中的类
REST handler which serves checkpoint statistics for subtasks.
TaskCheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskCheckpointStatisticsWithSubtaskDetails, TaskCheckpointMessageParameters>, ExecutionGraphCache, Executor, CheckpointStatsCache) - 类 的构造器org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
 
TaskCheckpointStatistics - org.apache.flink.runtime.rest.messages.checkpoints中的类
Checkpoint statistics for a single task.
TaskCheckpointStatistics(long, CheckpointStatsStatus, long, long, long, long, int, int) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
TaskCheckpointStatisticsHeaders - org.apache.flink.runtime.rest.messages.checkpoints中的类
TaskCheckpointStatisticsWithSubtaskDetails - org.apache.flink.runtime.rest.messages.checkpoints中的类
Task checkpoint statistics which also includes information about the sub task checkpoint statistics.
TaskCheckpointStatisticsWithSubtaskDetails(long, CheckpointStatsStatus, long, long, long, long, int, int, TaskCheckpointStatisticsWithSubtaskDetails.Summary, List<SubtaskCheckpointStatistics>) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment - org.apache.flink.runtime.rest.messages.checkpoints中的类
Alignment information for a specific checkpoint at a given task.
TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration - org.apache.flink.runtime.rest.messages.checkpoints中的类
Duration of a checkpoint split up into its synchronous and asynchronous part.
TaskCheckpointStatisticsWithSubtaskDetails.Summary - org.apache.flink.runtime.rest.messages.checkpoints中的类
Summary of the checkpoint statistics for a given task.
TaskConfig - org.apache.flink.runtime.operators.util中的类
Configuration class which stores all relevant parameters required to set up the Pact tasks.
TaskConfig(Configuration) - 类 的构造器org.apache.flink.runtime.operators.util.TaskConfig
Creates a new Task Config that wraps the given configuration.
taskContext - 类 中的变量org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
taskContext - 类 中的变量org.apache.flink.runtime.operators.JoinDriver
 
TaskContext<S,OT> - org.apache.flink.runtime.operators中的接口
The task context gives a driver (e.g., MapDriver, or JoinDriver) access to the runtime components and configuration that they can use to fulfil their task.
TaskDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
A task deployment descriptor contains all the information necessary to deploy a task on a task manager.
TaskDeploymentDescriptor(JobID, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation>, ExecutionAttemptID, AllocationID, int, int, int, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>) - 类 的构造器org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
TaskDeploymentDescriptor.MaybeOffloaded<T> - org.apache.flink.runtime.deployment中的类
Wrapper class for serialized values which may be offloaded to the BlobServer or not.
TaskDeploymentDescriptor.NonOffloaded<T> - org.apache.flink.runtime.deployment中的类
A serialized value that is not offloaded to the BlobServer.
TaskDeploymentDescriptor.Offloaded<T> - org.apache.flink.runtime.deployment中的类
Reference to a serialized value that was offloaded to the BlobServer.
TaskEvent - org.apache.flink.runtime.event中的类
Subclasses of this event are recognized as custom events that are not part of the core flink runtime.
TaskEvent() - 类 的构造器org.apache.flink.runtime.event.TaskEvent
 
TaskEventDispatcher - org.apache.flink.runtime.io.network中的类
The task event dispatcher dispatches events flowing backwards from a consuming task to the task producing the consumed result.
TaskEventDispatcher() - 类 的构造器org.apache.flink.runtime.io.network.TaskEventDispatcher
 
TaskEventHandler - org.apache.flink.runtime.io.network.api中的类
The event handler manages EventListener instances and allows to to publish events to them.
TaskEventHandler() - 类 的构造器org.apache.flink.runtime.io.network.api.TaskEventHandler
 
TaskException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception indicating a task related problem on the TaskExecutor.
TaskException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
TaskException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
TaskException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
TaskExecutionState - org.apache.flink.runtime.taskmanager中的类
This class represents an update about a task's execution state.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState) - 类 的构造器org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with no attached exception and no accumulators.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable) - 类 的构造器org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with an attached exception but no accumulators.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable, AccumulatorSnapshot, IOMetrics) - 类 的构造器org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with an attached exception.
TaskExecutor - org.apache.flink.runtime.taskexecutor中的类
TaskExecutor implementation.
TaskExecutor(RpcService, TaskManagerConfiguration, HighAvailabilityServices, TaskManagerServices, HeartbeatServices, TaskManagerMetricGroup, String, BlobCacheService, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskExecutor
 
TaskExecutorConnection - org.apache.flink.runtime.resourcemanager.registration中的类
This class is responsible for grouping the TaskExecutorGateway and the InstanceID of a registered task executor.
TaskExecutorConnection(ResourceID, TaskExecutorGateway) - 类 的构造器org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
TaskExecutorGateway - org.apache.flink.runtime.taskexecutor中的接口
TaskExecutor RPC gateway interface.
TaskExecutorLocalStateStoresManager - org.apache.flink.runtime.state中的类
This class holds the all TaskLocalStateStoreImpl objects for a task executor (manager).
TaskExecutorLocalStateStoresManager(boolean, File[], Executor) - 类 的构造器org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
TaskExecutorRegistrationSuccess - org.apache.flink.runtime.taskexecutor中的类
Base class for responses from the ResourceManager to a registration attempt by a TaskExecutor.
TaskExecutorRegistrationSuccess(InstanceID, ResourceID, ClusterInformation) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Create a new TaskExecutorRegistrationSuccess message.
TaskExecutorToResourceManagerConnection - org.apache.flink.runtime.taskexecutor中的类
The connection between a TaskExecutor and the ResourceManager.
TaskExecutorToResourceManagerConnection(Logger, RpcService, String, ResourceID, RetryingRegistrationConfiguration, int, HardwareDescription, String, ResourceManagerId, Executor, RegistrationConnectionListener<TaskExecutorToResourceManagerConnection, TaskExecutorRegistrationSuccess>) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
taskID - 类 中的变量org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
TaskInformation - org.apache.flink.runtime.executiongraph中的类
Container class for operator/task specific information which are stored at the ExecutionJobVertex.
TaskInformation(JobVertexID, String, int, int, String, Configuration) - 类 的构造器org.apache.flink.runtime.executiongraph.TaskInformation
 
TaskInputSplitProvider - org.apache.flink.runtime.taskmanager中的类
Implementation using ActorGateway to forward the messages.
TaskInputSplitProvider(ActorGateway, JobID, JobVertexID, ExecutionAttemptID, FiniteDuration) - 类 的构造器org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
TaskIOMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Metric group that contains shareable pre-defined IO-related metrics.
TaskIOMetricGroup(TaskMetricGroup) - 类 的构造器org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
TaskKvStateRegistry - org.apache.flink.runtime.query中的类
A helper for KvState registrations of a single task.
TaskLocalStateStore - org.apache.flink.runtime.state中的接口
Classes that implement this interface serve as a task-manager-level local storage for local checkpointed state.
TaskLocalStateStoreImpl - org.apache.flink.runtime.state中的类
Main implementation of a TaskLocalStateStore.
TaskLocalStateStoreImpl(JobID, AllocationID, JobVertexID, int, LocalRecoveryConfig, Executor) - 类 的构造器org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
TaskManagerActions - org.apache.flink.runtime.taskmanager中的接口
Interface for the communication of the Task with the TaskManager.
TaskManagerCliOptions - org.apache.flink.runtime.taskmanager中的类
The command line parameters passed to the TaskManager.
TaskManagerCliOptions() - 类 的构造器org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
TaskManagerConfiguration - org.apache.flink.runtime.taskexecutor中的类
Configuration object for TaskExecutor.
TaskManagerConfiguration(int, String[], Time, Time, Time, Time, Time, Configuration, boolean, FlinkUserCodeClassLoaders.ResolveOrder, String[], String, String, RetryingRegistrationConfiguration) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
TaskManagerDetailsHandler - org.apache.flink.runtime.rest.handler.taskmanager中的类
Handler which serves detailed TaskManager information.
TaskManagerDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagerDetailsInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
 
TaskManagerDetailsHeaders - org.apache.flink.runtime.rest.messages.taskmanager中的类
Headers for the TaskManagerDetailsHandler which serves the TaskManager details.
TaskManagerDetailsInfo - org.apache.flink.runtime.rest.messages.taskmanager中的类
Message containing base information about a TaskExecutor and more detailed metrics.
TaskManagerDetailsInfo(ResourceID, String, int, long, int, int, HardwareDescription, TaskManagerMetricsInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
TaskManagerDetailsInfo(TaskManagerInfo, TaskManagerMetricsInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
taskManagerDirectMemoryLimitMB() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskManagerEnv() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
TaskManagerException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Base exception thrown by the TaskExecutor.
TaskManagerException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerGateway - org.apache.flink.runtime.jobmanager.slots中的接口
Task manager gateway interface to communicate with the task manager.
taskManagerHeapSizeMB() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskManagerID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
taskManagerId() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
taskManagerIdParameter - 类 中的变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
TaskManagerIdPathParameter - org.apache.flink.runtime.rest.messages.taskmanager中的类
TaskManager id path parameter used by TaskManager related handlers.
TaskManagerIdPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
TaskManagerInfo - org.apache.flink.runtime.rest.messages.taskmanager中的类
Base class containing information for a TaskExecutor.
TaskManagerInfo(ResourceID, String, int, long, int, int, HardwareDescription) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
TaskManagerJobMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing everything belonging to a specific job, running on the TaskManager.
TaskManagerJobMetricGroup(MetricRegistry, TaskManagerMetricGroup, JobID, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
TaskManagerJobScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the JobMetricGroup.
TaskManagerJobScopeFormat(String, TaskManagerScopeFormat) - 类 的构造器org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
 
TaskManagerLocation - org.apache.flink.runtime.taskmanager中的类
This class encapsulates the connection information of a TaskManager.
TaskManagerLocation(ResourceID, InetAddress, int) - 类 的构造器org.apache.flink.runtime.taskmanager.TaskManagerLocation
Constructs a new instance connection info object.
TaskManagerLogFileHandler - org.apache.flink.runtime.rest.handler.taskmanager中的类
Rest handler which serves the log files from TaskExecutor.
TaskManagerLogFileHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
 
TaskManagerLogFileHeaders - org.apache.flink.runtime.rest.messages.taskmanager中的类
Headers for the TaskManagerLogFileHandler.
TaskManagerMessageParameters - org.apache.flink.runtime.rest.messages.taskmanager中的类
Message parameter for a TaskManager specific handler.
TaskManagerMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
TaskManagerMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing a TaskManager.
TaskManagerMetricGroup(MetricRegistry, String, String) - 类 的构造器org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
TaskManagerMetricsHandler - org.apache.flink.runtime.rest.handler.job.metrics中的类
Handler that returns TaskManager metrics.
TaskManagerMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - 类 的构造器org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
 
TaskManagerMetricsHeaders - org.apache.flink.runtime.rest.messages.job.metrics中的类
TaskManagerMetricsInfo - org.apache.flink.runtime.rest.messages.taskmanager中的类
Contains information about the TaskManager metrics.
TaskManagerMetricsInfo(long, long, long, long, long, long, long, long, long, long, long, long, long, long, List<TaskManagerMetricsInfo.GarbageCollectorInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
TaskManagerMetricsInfo.GarbageCollectorInfo - org.apache.flink.runtime.rest.messages.taskmanager中的类
Information about the garbage collector metrics.
TaskManagerMetricsMessageParameters - org.apache.flink.runtime.rest.messages.job.metrics中的类
TaskManagerMetricsMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
 
TaskManagerQueryScopeInfo(String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
TaskManagerQueryScopeInfo(String, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
TaskManagerRegistration - org.apache.flink.runtime.resourcemanager.slotmanager中的类
 
TaskManagerRegistration(TaskExecutorConnection, Collection<SlotID>) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
TaskManagerRunner - org.apache.flink.runtime.taskexecutor中的类
This class is the executable entry point for the task manager in yarn or standalone mode.
TaskManagerRunner(Configuration, ResourceID) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
TaskManagerRuntimeInfo - org.apache.flink.runtime.taskmanager中的接口
Interface to access TaskManager information.
TaskManagerScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the TaskManagerMetricGroup.
TaskManagerScopeFormat(String) - 类 的构造器org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
 
TaskManagerServices - org.apache.flink.runtime.taskexecutor中的类
Container for TaskExecutor services such as the MemoryManager, IOManager, NetworkEnvironment.
TaskManagerServicesConfiguration - org.apache.flink.runtime.taskexecutor中的类
Configuration for the task manager services such as the network environment, the memory manager, the io manager and the metric registry.
TaskManagerServicesConfiguration(InetAddress, String[], String[], boolean, NetworkEnvironmentConfiguration, QueryableStateConfiguration, int, long, MemoryType, boolean, float, long, RetryingRegistrationConfiguration, Optional<Time>) - 类 的构造器org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
TaskManagersFilterQueryParameter - org.apache.flink.runtime.rest.messages.job.metrics中的类
MessageQueryParameter for selecting task managers when aggregating metrics.
TaskManagersHandler - org.apache.flink.runtime.rest.handler.taskmanager中的类
Returns an overview over all registered TaskManagers of the cluster.
TaskManagersHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagersInfo, EmptyMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
 
TaskManagersHeaders - org.apache.flink.runtime.rest.messages.taskmanager中的类
Message headers for the TaskManagersHandler.
TaskManagersInfo(String, ExecutionState, long, long, long, IOMetricsInfo, Map<ExecutionState, Integer>) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TaskManagersInfo - org.apache.flink.runtime.rest.messages.taskmanager中的类
Class containing a collection of TaskManagerInfo.
TaskManagersInfo(Collection<TaskManagerInfo>) - 类 的构造器org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
TaskManagerSlot - org.apache.flink.runtime.clusterframework.types中的类
A TaskManagerSlot represents a slot located in a TaskManager.
TaskManagerSlot(SlotID, ResourceProfile, TaskExecutorConnection) - 类 的构造器org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
TaskManagerSlot.State - org.apache.flink.runtime.clusterframework.types中的枚举
State of the TaskManagerSlot.
TaskManagerSlotId - org.apache.flink.runtime.resourcemanager.slotmanager中的类
TaskManagerStdoutFileHandler - org.apache.flink.runtime.rest.handler.taskmanager中的类
Rest handler which serves the stdout file of the TaskExecutor.
TaskManagerStdoutFileHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
 
TaskManagerStdoutFileHeaders - org.apache.flink.runtime.rest.messages.taskmanager中的类
taskManagerTotalMemoryMB() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
TaskMetricGroup - org.apache.flink.runtime.metrics.groups中的类
Special MetricGroup representing a Flink runtime Task.
TaskMetricGroup(MetricRegistry, TaskManagerJobMetricGroup, JobVertexID, AbstractID, String, int, int) - 类 的构造器org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
taskName() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
taskName - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
TaskQueryScopeInfo(String, String, int) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
TaskQueryScopeInfo(String, String, int, String) - 类 的构造器org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
TaskScopeFormat - org.apache.flink.runtime.metrics.scope中的类
The scope format for the TaskMetricGroup.
TaskScopeFormat(String, TaskManagerJobScopeFormat) - 类 的构造器org.apache.flink.runtime.metrics.scope.TaskScopeFormat
 
TaskSlot - org.apache.flink.runtime.taskexecutor.slot中的类
Container for multiple Task belonging to the same slot.
TaskSlotTable - org.apache.flink.runtime.taskexecutor.slot中的类
Container for multiple TaskSlot instances.
TaskSlotTable(Collection<ResourceProfile>, TimerService<AllocationID>) - 类 的构造器org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
TaskState - org.apache.flink.runtime.checkpoint中的类
已过时。
Internal class for savepoint backwards compatibility. Don't use for other purposes.
TaskState(JobVertexID, int, int, int) - 类 的构造器org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
TaskStateManager - org.apache.flink.runtime.state中的接口
This interface provides methods to report and retrieve state for a task.
TaskStateManagerImpl - org.apache.flink.runtime.state中的类
This class is the default implementation of TaskStateManager and collaborates with the job manager through CheckpointResponder) as well as a task-manager-local state store.
TaskStateManagerImpl(JobID, ExecutionAttemptID, TaskLocalStateStore, JobManagerTaskRestore, CheckpointResponder) - 类 的构造器org.apache.flink.runtime.state.TaskStateManagerImpl
 
TaskStateSnapshot - org.apache.flink.runtime.checkpoint中的类
This class encapsulates state handles to the snapshots of all operator instances executed within one task.
TaskStateSnapshot() - 类 的构造器org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
TaskStateSnapshot(int) - 类 的构造器org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
TaskStateSnapshot(Map<OperatorID, OperatorSubtaskState>) - 类 的构造器org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
TaskStateStats - org.apache.flink.runtime.checkpoint中的类
Statistics for a single task/operator that gathers all statistics of its subtasks and provides summary statistics about all subtasks.
TaskStateStats.TaskStateStatsSummary - org.apache.flink.runtime.checkpoint中的类
Summary of the subtask stats of a single task/operator.
TaskStateStatsSummary() - 类 的构造器org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
 
TaskSubmissionException - org.apache.flink.runtime.taskexecutor.exceptions中的异常错误
Exception indicating a problem with the Task submission at the TaskException.
TaskSubmissionException(String) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
TaskSubmissionException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
TaskSubmissionException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
teardown() - 类 中的方法org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
teardown() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
teardown() - 类 中的方法org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
teardown() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
teardown() - 类 中的方法org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
teardown() - 接口 中的方法org.apache.flink.runtime.operators.ResettableDriver
 
tell(Object) - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - 接口 中的方法org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result with sender being the sender.
tell(Object) - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result with sender being the sender.
tell(Object) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
TempBarrier<T> - org.apache.flink.runtime.operators中的类
 
TempBarrier(AbstractInvokable, MutableObjectIterator<T>, TypeSerializerFactory<T>, MemoryManager, IOManager, int) - 类 的构造器org.apache.flink.runtime.operators.TempBarrier
 
tempBarriers - 类 中的变量org.apache.flink.runtime.operators.BatchTask
The optional temp barriers on the inputs for dead-lock breaking.
tempFileCounter - 类 中的变量org.apache.flink.runtime.blob.AbstractBlobCache
Counter to generate unique names for temporary files.
temporary(File) - 类 中的静态方法org.apache.flink.runtime.state.SnapshotDirectory
Creates a local temporary snapshot directory for the given path.
Terminable - org.apache.flink.runtime.iterative.task中的接口
Models the functionality that the termination of an iterative task can be requested from outside.
TERMINATED_PAYLOAD - 接口 中的静态变量org.apache.flink.runtime.jobmaster.LogicalSlot
 
terminateRpcEndpoint(RpcEndpoint, Time) - 类 中的静态方法org.apache.flink.runtime.rpc.RpcUtils
Shuts the given RpcEndpoint down and awaits its termination.
terminateRpcService(RpcService, Time) - 类 中的静态方法org.apache.flink.runtime.rpc.RpcUtils
Shuts the given rpc service down and waits for its termination.
terminateRpcServices(Time, RpcService...) - 类 中的静态方法org.apache.flink.runtime.rpc.RpcUtils
Shuts the given rpc services down and waits for their termination.
terminateTaskExecutor(int) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
TerminationEvent - org.apache.flink.runtime.iterative.event中的类
Signals that the iteration is completely executed, participating tasks must terminate now.
TerminationEvent() - 类 的构造器org.apache.flink.runtime.iterative.event.TerminationEvent
 
terminationModeQueryParameter - 类 中的变量org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
TerminationModeQueryParameter - org.apache.flink.runtime.rest.messages中的类
Termination mode for the JobTerminationHandler.
TerminationModeQueryParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
TerminationModeQueryParameter.TerminationMode - org.apache.flink.runtime.rest.messages中的枚举
Supported termination modes.
terminationRequested() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
terminationRequested() - 类 中的方法org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
terminationRequested() - 接口 中的方法org.apache.flink.runtime.iterative.task.Terminable
 
terminationSignaled() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
testHash(int) - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter
 
thenAcceptAsyncIfNotDone(CompletableFuture<IN>, Executor, Consumer<? super IN>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
This function takes a CompletableFuture and a consumer to accept the result of this future.
thenApplyAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends OUT>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
This function takes a CompletableFuture and a function to apply to this future.
thenComposeAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends CompletionStage<OUT>>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
This function takes a CompletableFuture and a function to compose with this future.
ThreadBase(ExceptionHandler<IOException>, String, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Creates a new thread.
ThrowableAnnotation - org.apache.flink.runtime.throwable中的注释类型
Annotation to classify subclasses of Throwable into categories w.r.t. recovery.
ThrowableClassifier - org.apache.flink.runtime.throwable中的类
Helper class, given a exception do the classification.
ThrowableClassifier() - 类 的构造器org.apache.flink.runtime.throwable.ThrowableClassifier
 
ThrowableType - org.apache.flink.runtime.throwable中的枚举
Enum for the classification of Throwable objects into failure/recovery classes.
ticketCacheEntry() - 类 中的静态方法org.apache.flink.runtime.security.KerberosUtils
 
timeout - 类 中的变量org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
 
TimeoutListener<K> - org.apache.flink.runtime.taskexecutor.slot中的接口
Listener for timeout events by the TimerService.
timeoutPendingSlotRequest(SlotRequestId) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
 
timeoutSlot(AllocationID, UUID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.SlotActions
Timeout the task slot for the given allocation id.
TimerService<K> - org.apache.flink.runtime.taskexecutor.slot中的类
Service to register timeouts for a given key.
TimerService(ScheduledExecutorService, long) - 类 的构造器org.apache.flink.runtime.taskexecutor.slot.TimerService
 
toArray() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toArray(T1[]) - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toArray(O[]) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
 
toArray() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
 
toArray() - 类 中的方法org.apache.flink.runtime.util.LongArrayList
 
toAsyncSnapshotFutureTask(CloseableRegistry) - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
Creates a future task from this and registers it with the given CloseableRegistry.
toBuffer(AbstractEvent) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toBufferConsumer(AbstractEvent) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toFiniteDuration(Time) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Converts Flink time into a FiniteDuration.
toJava(Future<U>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Converts a Scala Future to a CompletableFuture.
toJava(Option<T>) - 类 中的静态方法org.apache.flink.runtime.util.ScalaUtils
Converts a Scala Option to a Optional.
toJobExecutionResult(ClassLoader) - 类 中的方法org.apache.flink.runtime.client.SerializedJobExecutionResult
 
toJobExecutionResult(ClassLoader) - 类 中的方法org.apache.flink.runtime.jobmaster.JobResult
Converts the JobResult to a JobExecutionResult.
toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle>, KeyGroupRangeOffsets) - 接口 中的静态方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
Helper method that takes a SnapshotResult and a KeyGroupRangeOffsets and creates a SnapshotResult by combining the key groups offsets with all the present stream state handles.
toSerializedEvent(AbstractEvent) - 类 中的静态方法org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toString() - 类 中的方法org.apache.flink.runtime.blob.BlobKey
 
toString() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointOptions
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.MasterState
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorState
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.SubtaskState
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskState
已过时。
 
toString() - 类 中的方法org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.RemoveResource
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.StopCluster
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceID
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
toString() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
 
toString() - 类 中的方法org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
toString() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
toString() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
toString() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionLocation
 
toString() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
toString() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterInformation
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionEdge
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
toString() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
toString() - 类 中的方法org.apache.flink.runtime.instance.AkkaActorGateway
 
toString() - 类 中的方法org.apache.flink.runtime.instance.HardwareDescription
 
toString() - 类 中的方法org.apache.flink.runtime.instance.Instance
 
toString() - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
toString() - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
 
toString() - 类 中的方法org.apache.flink.runtime.instance.Slot
 
toString() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
 
toString() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.JobEdge
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
toString() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
toString() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
 
toString() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
toString() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
toString() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
toString() - 类 中的方法org.apache.flink.runtime.jobmanager.SubmittedJobGraph
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotReport
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
toString() - 类 中的方法org.apache.flink.runtime.jobmaster.SlotRequestId
 
toString() - 类 中的方法org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
toString() - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
toString() - 类 中的方法org.apache.flink.runtime.messages.Acknowledge
 
toString() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
toString() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
toString() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
toString() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
toString() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobDetails
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
toString() - 类 中的方法org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
toString() - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricDump
 
toString() - 类 中的方法org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
toString() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
toString() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
toString() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
 
toString() - 类 中的方法org.apache.flink.runtime.operators.util.BitSet
 
toString() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
toString() - 类 中的方法org.apache.flink.runtime.operators.util.BloomFilter
 
toString() - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
 
toString() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
 
toString() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
 
toString() - 类 中的方法org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
 
toString() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
toString() - 类 中的方法org.apache.flink.runtime.registration.RegistrationResponse.Decline
 
toString() - 类 中的方法org.apache.flink.runtime.registration.RegistrationResponse.Success
 
toString() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
 
toString() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
 
toString() - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
Returns visualized routing rules.
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.job.metrics.Metric
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
 
toString() - 类 中的方法org.apache.flink.runtime.rest.messages.JobPlanInfo
 
toString() - 枚举 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
 
toString() - 枚举 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
 
toString() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
toString() - 类 中的方法org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
toString() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
toString() - 类 中的方法org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
toString() - 类 中的方法org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
toString() - 类 中的方法org.apache.flink.runtime.state.AbstractSnapshotStrategy
 
toString() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
 
toString() - 类 中的方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
toString() - 类 中的方法org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.DirectoryStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.filesystem.FileStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
toString() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
toString() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
 
toString() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable.StateTableEntry
 
toString() - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
toString() - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
toString() - 类 中的方法org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
 
toString() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
toString() - 类 中的方法org.apache.flink.runtime.state.KeyGroupsStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryConfig
 
toString() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
toString() - 类 中的方法org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
toString() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
toString() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryStateBackend
 
toString() - 类 中的方法org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
toString() - 类 中的方法org.apache.flink.runtime.state.OperatorStreamStateHandle
 
toString() - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
toString() - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
toString() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
toString() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
toString() - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry.Result
 
toString() - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
 
toString() - 类 中的方法org.apache.flink.runtime.state.SnapshotDirectory
 
toString() - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
toString() - 类 中的方法org.apache.flink.runtime.state.VoidNamespace
 
toString() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
toString() - 类 中的方法org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
 
toString() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
toString() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotReport
 
toString() - 类 中的方法org.apache.flink.runtime.taskexecutor.SlotStatus
 
toString() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
 
toString() - 类 中的方法org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
toString() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
toString() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskExecutionState
 
toString() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
toString() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
 
toString() - 类 中的方法org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
 
toString() - 类 中的方法org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
totalKeyGroups - 类 中的变量org.apache.flink.runtime.state.KeyGroupPartitioner
The total number of key-groups in the job.
totalNumberOfSlots() - 类 中的方法org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
toTime(FiniteDuration) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Converts FiniteDuration into Flink time.
touch() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
touch(Object) - 类 中的方法org.apache.flink.runtime.rest.handler.router.RoutedRequest
 
toUUID() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherId
 
toUUID() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterId
Creates a UUID with the bits from this JobMasterId.
toUUID() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerId
Creates a UUID with the bits from this ResourceManagerId.
transform(N, T, StateTransformationFunction<S, T>) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
Applies the given StateTransformationFunction to the state (1st input argument), using the given value as second input argument.
TransientBlobCache - org.apache.flink.runtime.blob中的类
Provides access to transient BLOB files stored at the BlobServer.
TransientBlobCache(Configuration, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.blob.TransientBlobCache
Instantiates a new BLOB cache.
TransientBlobKey - org.apache.flink.runtime.blob中的类
BLOB key referencing transient BLOB files.
TransientBlobKey() - 类 的构造器org.apache.flink.runtime.blob.TransientBlobKey
Constructs a new BLOB key.
TransientBlobService - org.apache.flink.runtime.blob中的接口
A service to retrieve transient binary large objects (BLOBs) which are deleted on the BlobServer when they are retrieved.
TRANSPORT_TYPE - 类 中的静态变量org.apache.flink.runtime.io.network.netty.NettyConfig
 
TransportException - org.apache.flink.runtime.io.network.netty.exception中的异常错误
 
TransportException(String, SocketAddress) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.TransportException
 
TransportException(String, SocketAddress, Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.network.netty.exception.TransportException
 
triggerCheckpoint(long, boolean) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a new standard checkpoint and uses the given timestamp as the checkpoint timestamp.
triggerCheckpoint(long, CheckpointProperties, String, boolean) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
triggerCheckpoint(long, long, Executor) - 接口 中的方法org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
This method is called by the checkpoint coordinator prior when triggering a checkpoint, prior to sending the "trigger checkpoint" messages to the source tasks.
triggerCheckpoint(long, long, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
Trigger a new checkpoint on the task of this execution.
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called to trigger a checkpoint, asynchronously by the checkpoint coordinator.
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Trigger for the given task a checkpoint.
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
TriggerCheckpoint - org.apache.flink.runtime.messages.checkpoint中的类
This message is sent from the JobMaster to the TaskExecutor to tell a certain task to trigger its checkpoint.
TriggerCheckpoint(JobID, ExecutionAttemptID, long, long, CheckpointOptions) - 类 的构造器org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Trigger the checkpoint for the given task.
triggerCheckpointBarrier(long, long, CheckpointOptions) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
Calls the invokable to trigger a checkpoint.
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called when a checkpoint is triggered as a result of receiving checkpoint barriers on all input streams.
triggerFullRecovery() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
 
triggerFullRecovery() - 接口 中的方法org.apache.flink.runtime.executiongraph.restart.RestartCallback
Triggers a full recovery in the target ExecutionGraph.
TriggerHandler(GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<B, TriggerResponse, M>) - 类 的构造器org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
 
TriggerId - org.apache.flink.runtime.rest.messages中的类
Identifies a savepoint trigger request.
TriggerId() - 类 的构造器org.apache.flink.runtime.rest.messages.TriggerId
 
TriggerId.TriggerIdDeserializer - org.apache.flink.runtime.rest.messages中的类
JSON deserializer for TriggerId.
TriggerId.TriggerIdSerializer - org.apache.flink.runtime.rest.messages中的类
JSON serializer for TriggerId.
TriggerIdDeserializer() - 类 的构造器org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer
 
triggerIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
 
triggerIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
 
triggerIdPathParameter - 类 中的变量org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
 
TriggerIdPathParameter - org.apache.flink.runtime.rest.messages中的类
MessagePathParameter for the trigger id of an asynchronous operation.
TriggerIdPathParameter() - 类 的构造器org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
TriggerIdSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
 
triggerMasterHooks(Collection<MasterTriggerRestoreHook<?>>, long, long, Executor, Time) - 类 中的静态方法org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Triggers all given master hooks and returns state objects for each hook that produced a state.
triggerNextSuperstep() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
triggerOperation(HandlerRequest<B, M>, T) - 类 中的方法org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
Trigger the asynchronous operation and return its future result.
triggerOperation(HandlerRequest<EmptyRequestBody, RescalingTriggerMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
 
triggerOperation(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
 
triggerOperation(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>, RestfulGateway) - 类 中的方法org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskActions
Check the execution state of the execution producing a result partition.
TriggerRegistrationAtJobManager - org.apache.flink.runtime.clusterframework.messages中的类
Causes the resource manager to try and apply at the leader JobManager.
TriggerRegistrationAtJobManager(ActorRef) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
TriggerRegistrationAtJobManager(String) - 类 的构造器org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
TriggerResponse - org.apache.flink.runtime.rest.handler.async中的类
Response to the triggering of an asynchronous operation.
TriggerResponse(TriggerId) - 类 的构造器org.apache.flink.runtime.rest.handler.async.TriggerResponse
 
triggerSavepoint(long, String) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a savepoint with the given savepoint directory as a target.
triggerSavepoint(JobID, String, boolean, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
 
triggerSavepoint(String, boolean, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
triggerSavepoint(String, boolean, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers taking a savepoint of the executed job.
triggerSavepoint(JobID, String, boolean) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
triggerSavepoint(JobID, String, boolean, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
Triggers a savepoint with the given savepoint directory as a target.
triggerStackTraceSample(ExecutionJobVertex) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
已过时。
triggerStackTraceSample(ExecutionVertex[], int, Time, int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Triggers a stack trace sample to all tasks.
tryAdd(AbstractCheckpointStats) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
Try to add the checkpoint to the cache.
tryAssignPayload(LogicalSlot.Payload) - 类 中的方法org.apache.flink.runtime.instance.SharedSlot
 
tryAssignPayload(LogicalSlot.Payload) - 类 中的方法org.apache.flink.runtime.instance.SimpleSlot
Atomically sets the executed vertex, if no vertex has been assigned to this slot so far.
tryAssignPayload(LogicalSlot.Payload) - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
Tries to assign a payload to this slot.
tryAssignPayload(PhysicalSlot.Payload) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot
Tries to assign the given payload to this allocated slot.
tryAssignPayload(LogicalSlot.Payload) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
tryGet(long) - 类 中的方法org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
Try to look up a checkpoint by it's ID in the cache.
tryLoadWebContent(GatewayRetriever<? extends T>, Time, File) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
Checks whether the flink-runtime-web dependency is available and if so returns a StaticFileServerHandler which can serve the static file contents.
tryMarkSlotActive(JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Try to mark the specified slot as active if it has been allocated by the given job.
tryReconnect() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
 
trySetCount(ZooKeeperVersionedValue<Integer>, int) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
TtlSerializer(TypeSerializer<Long>, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
TtlSerializer(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - 类 的构造器org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
 
TtlSerializerSnapshot() - 类 的构造器org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
 
TtlStateFactory<K,N,SV,TTLSV,S extends org.apache.flink.api.common.state.State,IS extends S> - org.apache.flink.runtime.state.ttl中的类
This state factory wraps state objects, produced by backends, with TTL logic.
TtlStateFactory.TtlSerializer<T> - org.apache.flink.runtime.state.ttl中的类
Serializer for user state value with TTL.
TtlStateFactory.TtlSerializerSnapshot<T> - org.apache.flink.runtime.state.ttl中的类
A TypeSerializerSnapshot for TtlSerializer.
ttlTimeProvider - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
ttlTimeProvider - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
TtlTimeProvider - org.apache.flink.runtime.state.ttl中的接口
Provides time to TTL logic to judge about state expiration.
TtlUtils - org.apache.flink.runtime.state.ttl中的类
Common functions related to State TTL.
TtlUtils() - 类 的构造器org.apache.flink.runtime.state.ttl.TtlUtils
 
TtlValue<T> - org.apache.flink.runtime.state.ttl中的类
This class wraps user value of state with TTL.
TtlValue(T, long) - 类 的构造器org.apache.flink.runtime.state.ttl.TtlValue
 

U

unassignPendingSlotRequest() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
 
unassignPendingTaskManagerSlot() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
uncaughtException(Thread, Throwable) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
uncaughtException(Thread, Throwable) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
 
uncaughtException(Thread, Throwable) - 类 中的方法org.apache.flink.runtime.util.FatalExitExceptionHandler
 
UncompressedStreamCompressionDecorator - org.apache.flink.runtime.state中的类
This implementation does not decorate the stream with any compression.
UncompressedStreamCompressionDecorator() - 类 的构造器org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
UnfencedMessage<P> - org.apache.flink.runtime.rpc.messages中的类
Wrapper class indicating a message which is not required to match the fencing token as it is used by the FencedMainThreadExecutable to run code in the main thread without a valid fencing token.
UnfencedMessage(P) - 类 的构造器org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
unhandledError(String, Throwable) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
unhandledError(String, Throwable) - 类 中的方法org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
UnilateralSortMerger<E> - org.apache.flink.runtime.operators.sort中的类
The UnilateralSortMerger is a full fledged sorter.
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean, boolean) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean, boolean, InMemorySorterFactory<E>) - 类 的构造器org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger.ChannelWithBlockCount - org.apache.flink.runtime.operators.sort中的类
 
UnilateralSortMerger.CircularElement<E> - org.apache.flink.runtime.operators.sort中的类
Class representing buffers that circulate between the reading, sorting and spilling thread.
UnilateralSortMerger.CircularQueues<E> - org.apache.flink.runtime.operators.sort中的类
Collection of queues that are used for the communication between the threads.
UnilateralSortMerger.ReadingThread<E> - org.apache.flink.runtime.operators.sort中的类
The thread that consumes the input data and puts it into a buffer that will be sorted.
UnilateralSortMerger.SortingThread<E> - org.apache.flink.runtime.operators.sort中的类
The thread that sorts filled buffers.
UnilateralSortMerger.SpillingThread - org.apache.flink.runtime.operators.sort中的类
The thread that handles the spilling of intermediate results and sets up the merging.
UnilateralSortMerger.ThreadBase<E> - org.apache.flink.runtime.operators.sort中的类
Base class for all working threads in this sort-merger.
uninstall() - 类 中的方法org.apache.flink.runtime.security.modules.HadoopModule
 
uninstall() - 类 中的方法org.apache.flink.runtime.security.modules.JaasModule
 
uninstall() - 接口 中的方法org.apache.flink.runtime.security.modules.SecurityModule
Uninstall the security module.
uninstall() - 类 中的方法org.apache.flink.runtime.security.modules.ZooKeeperModule
 
UnionInputGate - org.apache.flink.runtime.io.network.partition.consumer中的类
Input gate wrapper to union the input from multiple input gates.
UnionInputGate(InputGate...) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
UnionWithTempOperator<T> - org.apache.flink.runtime.operators中的类
 
UnionWithTempOperator() - 类 的构造器org.apache.flink.runtime.operators.UnionWithTempOperator
 
UNKNOWN - 类 中的静态变量org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
UNKNOWN - 类 中的静态变量org.apache.flink.runtime.util.EnvironmentInformation
 
UnknownKvStateLocation - org.apache.flink.runtime.query中的异常错误
Thrown if there is no KvStateLocation found for the requested registration name.
UnknownKvStateLocation(String) - 异常错误 的构造器org.apache.flink.runtime.query.UnknownKvStateLocation
 
UnknownTaskExecutorException - org.apache.flink.runtime.resourcemanager.exceptions中的异常错误
Exception denoting that a requested TaskExecutor could not be found.
UnknownTaskExecutorException(ResourceID) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.exceptions.UnknownTaskExecutorException
 
unmonitorTarget(ResourceID) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManager
Stops monitoring the heartbeat target with the associated resource ID.
unmonitorTarget(ResourceID) - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
unregister(Metric, String, AbstractMetricGroup) - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
Un-registers the given Metric with this registry.
unregister(Metric, String, AbstractMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
 
unregister(Metric, String, AbstractMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
unregisterAll() - 类 中的方法org.apache.flink.runtime.query.TaskKvStateRegistry
Unregisters all registered KvState instances from the KvStateRegistry.
unregisterAllTaskManagers() - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
Unregisters all currently registered TaskManagers from the InstanceManager.
unregisterAllTimeouts() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister all timeouts.
unregisterChannelToBeRemovedAtShudown(FileIOChannel.ID) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel from the list of channels that are to be removed at shutdown.
UnregisteredJobManagerJobMetricGroup() - 类 的构造器org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup
 
UnregisteredJobManagerJobMetricGroupFactory - org.apache.flink.runtime.jobmaster.factories中的枚举
UnregisteredMetricGroups - org.apache.flink.runtime.metrics.groups中的类
A collection of safe drop-in replacements for existing ComponentMetricGroups.
UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for JobManagerJobMetricGroups.
UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for JobManagerMetricGroups.
UnregisteredMetricGroups.UnregisteredOperatorMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for OperatorMetricGroups.
UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for TaskManagerJobMetricGroups.
UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for TaskManagerMetricGroups.
UnregisteredMetricGroups.UnregisteredTaskMetricGroup - org.apache.flink.runtime.metrics.groups中的类
A safe drop-in replacement for TaskMetricGroups.
UnregisteredOperatorMetricGroup() - 类 的构造器org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredOperatorMetricGroup
 
UnregisteredTaskManagerJobMetricGroup() - 类 的构造器org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
 
UnregisteredTaskManagerMetricGroup() - 类 的构造器org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup
 
UnregisteredTaskMetricGroup() - 类 的构造器org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
 
UnRegisterInfoMessageListener - org.apache.flink.runtime.clusterframework.messages中的类
This message signals to the resource master to register the sender as an info message listener.
unRegisterInfoMessageListener(String) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Unregisters an info message listener.
unRegisterInfoMessageListener(String) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Unregisters an infoMessage listener
unregisterJob(JobID) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterJob(JobID) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job from the library cache manager.
unregisterKvState(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Unregisters the KvState instance identified by the given KvStateID.
unregisterListener(JobID) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
Unregisters the listener with the registry.
unregisterOpenChannelToBeRemovedAtShudown(FileIOChannel) - 类 中的方法org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel reader/writer from the list of channels that are to be removed at shutdown.
unregisterPartition(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
Removes the given partition from listening to incoming task events, thus forbidding calls to TaskEventDispatcher.subscribeToEvent(ResultPartitionID, EventListener, Class).
unregisterReference(SharedStateRegistryKey) - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
Releases one reference to the given shared state in the registry.
unregisterSlotRequest(AllocationID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Cancels and removes a pending slot request with the given allocation id.
unregisterTask(JobID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterTask(JobID, ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job task execution from the library cache manager.
unregisterTask(Task) - 类 中的方法org.apache.flink.runtime.io.network.NetworkEnvironment
 
unregisterTaskManager(InstanceID, boolean) - 类 中的方法org.apache.flink.runtime.instance.InstanceManager
Unregisters the TaskManager with the given instance id.
unregisterTaskManager(InstanceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Unregisters the task manager identified by the given instance id and its associated slots from the slot manager.
unregisterTaskManagersAndReleaseResources() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
unregisterTimeout(K) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister the timeout for the given key.
unsynchronizedGetNumberOfQueuedBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
unsynchronizedGetNumberOfQueuedBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
Makes a best effort to get the current size of the queue.
UntypedResponseMessageHeaders<R extends RequestBody,M extends MessageParameters> - org.apache.flink.runtime.rest.messages中的接口
Message headers for a web handler request.
unwrap() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
unwrap() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
update(long) - 类 中的方法org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
update() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
Trigger fetching of metrics.
update() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
This method can be used to signal this MetricFetcher that the metrics are still in use and should be updated.
update() - 枚举 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
 
update(StateEntry<K, N, V>, V) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
Update the value of the last returned entry from the next() method.
update(List<T>) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalListState
Updates the operator state accessible by AppendingState.get() by updating existing values to to the given list of values.
update(List<S>) - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
updateAccumulators(AccumulatorSnapshot) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the accumulators during the runtime of a job.
updateAllocation(AllocationID, JobID) - 类 中的方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
updateCoLocationGroup(CoLocationGroup) - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
 
updateElementSerializer(TypeSerializer<T>) - 类 中的方法org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
 
updateGlobalAggregate(String, Object, byte[]) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
 
updateGlobalAggregate(String, Object, byte[]) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Update the aggregate and return the new value.
updateGlobalAggregate(String, Object, AggregateFunction<IN, ACC, OUT>) - 接口 中的方法org.apache.flink.runtime.taskexecutor.GlobalAggregateManager
Update the global aggregate and return the new value.
updateGlobalAggregate(String, Object, AggregateFunction<IN, ACC, OUT>) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcGlobalAggregateManager
 
updateGlobalAggregate(String, Object, AggregateFunction<IN, ACC, OUT>) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayGlobalAggregateManager
 
updateGlobalAggregatesAndReset(String[], Value[]) - 类 中的方法org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
updateInputChannel(InputChannelDeploymentDescriptor) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
updateInternal(SV) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalAppendingState
Update internally stored value.
updateKeySerializer(TypeSerializer<K>) - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
updateKvStateLocationOracle(JobID, KvStateLocationOracle) - 接口 中的方法org.apache.flink.runtime.query.KvStateClientProxy
Updates the active Job Manager in case of change.
updateMatch(BT) - 类 中的方法org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
updateMatch(T) - 类 中的方法org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
updateMatch(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
This method can be called after getMatchFor returned a match.
updateNamespaceSerializer(TypeSerializer<N>) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - 类 中的方法org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Update the task where the given partitions can be found.
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Update the task where the given partitions can be found.
updatePartitionStateSerializer(TypeSerializer<S>) - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
 
updateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
updateState(TaskExecutionState) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the state of one of the ExecutionVertex's Execution attempts.
updateStateSerializer(TypeSerializer<S>) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
 
updateStatistics(BufferConsumer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
updateStatistics(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
updateTableEntryWithReduce(T) - 类 中的方法org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Looks up the table entry that has the same key as the given record, and updates it by performing a reduce step.
updateTaskExecutionState(TaskExecutionState) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
Updates the task execution state for a given task.
updateTaskExecutionState(TaskExecutionState) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
Updates the task execution state for a given task.
updateTaskExecutionState(TaskExecutionState) - 类 中的方法org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
updateTaskExecutionState(TaskExecutionState) - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about the task execution state update.
updateTmpDirectoriesInConfiguration(Configuration, String) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Set temporary configuration directories if necessary.
updateValueSerializer(TypeSerializer<V>) - 类 中的方法org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
 
uploadDir - 类 中的变量org.apache.flink.runtime.rest.RestServerEndpoint
 
uploadFile(JobID, Path) - 类 中的方法org.apache.flink.runtime.blob.BlobClient
Uploads a single file to the PermanentBlobService of the given BlobServer.
uploadFiles(InetSocketAddress, Configuration, JobID, List<Path>) - 类 中的静态方法org.apache.flink.runtime.blob.BlobClient
Uploads the JAR files to the PermanentBlobService of the BlobServer at the given address with HA as configured.
uploadJobGraphFiles(JobGraph, Collection<Path>, Collection<Tuple2<String, Path>>, SupplierWithException<BlobClient, IOException>) - 枚举 中的静态方法org.apache.flink.runtime.client.ClientUtils
Uploads the given jars and artifacts required for the execution of the given JobGraph using the BlobClient from the given Supplier.
UPPER_BOUND_MAX_PARALLELISM - 类 中的静态变量org.apache.flink.runtime.state.KeyGroupRangeAssignment
The (inclusive) upper bound for max parallelism
UpTimeGauge - org.apache.flink.runtime.executiongraph.metrics中的类
A gauge that returns (in milliseconds) how long a job has been running.
UpTimeGauge(ExecutionGraph) - 类 的构造器org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
uri() - 类 中的方法org.apache.flink.runtime.rest.handler.router.RouteResult
Returns the original request URI.
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobConfigHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobPlanHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
 
URL - 类 中的静态变量org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
 
useLocalCommunication() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
 
useNamespaceAndEnsurePath(CuratorFramework, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
Returns a facade of the client that uses the specified namespace, and ensures that all nodes in the path exist.
UserAccumulator - org.apache.flink.runtime.rest.messages.job中的类
User accumulator info.
UserAccumulator(String, String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.job.UserAccumulator
 
userClassloader - 类 中的变量org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
The user code classloader.
userCodeClassLoader - 类 中的变量org.apache.flink.runtime.operators.chaining.ChainedDriver
 
userCodeClassLoader - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
userCodeClassLoader - 类 中的变量org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
 
UserTaskAccumulator(String, String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
usesConvergenceCriterion() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
usesImplicitConvergenceCriterion() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
 
useTicketCache() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
 

V

validateAndNormalizeUri(URI) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
Checks and normalizes the given URI.
validateClassLoadable(ClassNotFoundException, ClassLoader) - 类 中的静态方法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() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
Validates that the method call happens in the RPC endpoint's main thread.
value - 类 中的变量org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
VALUE_NOT_SET - 类 中的静态变量org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.akka.ListeningBehaviour
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.client.ClientUtils
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.clusterframework.ApplicationStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.execution.ExecutionState
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.network.buffer.BufferListener.NotificationResult
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.DistributionPattern
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.JobStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.ScheduleMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.HighAvailabilityMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.JobManagerMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.scheduler.Locality
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.RescalingBehaviour
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.minicluster.RpcServiceSharing
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.operators.DamBehavior
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.operators.DriverStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.operators.shipping.ShipStrategyType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.operators.util.LocalStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.HttpMethodWrapper
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.JobRestEndpointFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.SessionRestEndpointFactory
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.util.RestConstants
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rpc.akka.ControlMessages
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.CheckpointedStateScope
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters.StateTypeHint
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.OperatorStateHandle.Mode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.taskexecutor.FileType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.throwable.ThrowableType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
返回带有指定名称的该类型的枚举常量。
valueOrNull(Object) - 类 中的静态方法org.apache.flink.runtime.metrics.scope.ScopeFormat
 
values() - 枚举 中的静态方法org.apache.flink.runtime.akka.ListeningBehaviour
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.CheckpointType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.client.ClientUtils
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.clusterframework.ApplicationStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.execution.ExecutionState
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.network.buffer.BufferListener.NotificationResult
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.DistributionPattern
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.JobStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobgraph.ScheduleMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.HighAvailabilityMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.JobManagerMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.scheduler.Locality
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.RescalingBehaviour
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.minicluster.RpcServiceSharing
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.operators.DamBehavior
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.operators.DriverStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.operators.shipping.ShipStrategyType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.operators.util.LocalStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.HttpMethodWrapper
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.JobRestEndpointFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.SessionRestEndpointFactory
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.util.RestConstants
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rpc.akka.ControlMessages
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.CheckpointedStateScope
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters.StateTypeHint
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.OperatorStateHandle.Mode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.taskexecutor.FileType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.throwable.ThrowableType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
valueSerializer - 类 中的变量org.apache.flink.runtime.state.heap.AbstractHeapState
 
variables - 类 中的变量org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The map containing all variables and their associated values, lazily computed.
verifyEmpty() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
Checks if the memory manager all memory available.
verifyEndOfSuperstepState() - 类 中的方法org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
version() - 类 中的方法org.apache.flink.runtime.checkpoint.MasterState
 
VERSION - 类 中的静态变量org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
The savepoint version.
VERSION - 类 中的静态变量org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
The savepoint version.
VERSION - 类 中的静态变量org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
VERSION - 类 中的静态变量org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
VERTEX_TASK_FIELD_ID - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
VERTEX_TASK_FIELD_NAME - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
VERTEX_TASK_FIELD_NOW - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
VERTEX_TASK_FIELD_TASK_MANAGERS - 类 中的静态变量org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
 
vertexID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
vertexID - 类 中的变量org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
vertexId - 类 中的变量org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
vertexId() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
VertexTaskDetail(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - 类 的构造器org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
ViewUpdater - org.apache.flink.runtime.metrics中的类
The ViewUpdater is responsible for updating all metrics that implement the View interface.
ViewUpdater(ScheduledExecutorService) - 类 的构造器org.apache.flink.runtime.metrics.ViewUpdater
 
visit(String, Object) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visit(int, int, String, String, String, String[]) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
visitAnnotation(String, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitAnnotation(String, boolean) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitAnnotation(String, boolean) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
visitAnnotationDefault() - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitArray(String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitClassType(String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitEnum(String, String, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitField(int, String, String, String, Object) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
visitFieldInsn(int, String, String, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitInnerClassType(String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitLdcInsn(Object) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitLocalVariable(String, String, String, Label, Label, int) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethod(int, String, String, String, String[]) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor
 
visitMethodInsn(int, String, String, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethodInsn(int, String, String, String, boolean) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMultiANewArrayInsn(String, int) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitParameterAnnotation(int, String, boolean) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitParameterType() - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitReturnType() - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitTryCatchBlock(Label, Label, Label, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitTypeAnnotation(int, TypePath, String, boolean) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
visitTypeInsn(int, String) - 类 中的方法org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
VoidBackPressureStatsTracker - org.apache.flink.runtime.rest.handler.legacy.backpressure中的枚举
BackPressureStatsTracker implementation which always returns no back pressure statistics.
VoidBlobStore - org.apache.flink.runtime.blob中的类
A blob store doing nothing.
VoidBlobStore() - 类 的构造器org.apache.flink.runtime.blob.VoidBlobStore
 
VoidBlobWriter - org.apache.flink.runtime.blob中的类
BlobWriter which does not support writing BLOBs to a store.
VoidBlobWriter() - 类 的构造器org.apache.flink.runtime.blob.VoidBlobWriter
 
VoidHistoryServerArchivist - org.apache.flink.runtime.dispatcher中的枚举
No-op implementation of the HistoryServerArchivist.
VoidMetricFetcher - org.apache.flink.runtime.rest.handler.legacy.metrics中的枚举
No-op implementation of the MetricFetcher.
VoidNamespace - org.apache.flink.runtime.state中的类
Singleton placeholder class for state without a namespace.
VoidNamespaceSerializer - org.apache.flink.runtime.state中的类
Serializer for VoidNamespace.
VoidNamespaceSerializer() - 类 的构造器org.apache.flink.runtime.state.VoidNamespaceSerializer
 
VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot - org.apache.flink.runtime.state中的类
Serializer configuration snapshot for compatibility and format evolution.
VoidNamespaceSerializerSnapshot() - 类 的构造器org.apache.flink.runtime.state.VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot
 
VoidNamespaceTypeInfo - org.apache.flink.runtime.state中的类
TypeInformation for VoidNamespace.
VoidNamespaceTypeInfo() - 类 的构造器org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 

W

waitForAll(Collection<? extends CompletableFuture<?>>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
Creates a future that is complete once all of the given futures have completed.
waitForFirstBlock() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
waitForOtherWorkers() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
Wait on the barrier.
waitForSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Waits (blocking) on barrier.
waitUntilTerminal() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
 
wasQuarantinedBy(String, ActorSystem) - 类 中的方法org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
wasQuarantinedBy(String, ActorSystem) - 接口 中的方法org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system was quarantined by the given remote actor system.
WebContentHandlerSpecification - org.apache.flink.runtime.rest.handler.legacy.files中的类
Rest handler specification for the web content handler.
WebHandler - org.apache.flink.runtime.rest.handler中的接口
Marker interface for web handlers which can describe their paths.
WebMonitor - org.apache.flink.runtime.webmonitor中的接口
Interface for web monitors.
WebMonitorEndpoint<T extends RestfulGateway> - org.apache.flink.runtime.webmonitor中的类
Rest endpoint which serves the web frontend REST calls.
WebMonitorEndpoint(RestServerEndpointConfiguration, GatewayRetriever<? extends T>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 类 的构造器org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
WebMonitorExtension - org.apache.flink.runtime.webmonitor中的接口
Interface for WebMonitorEndpoint extensions.
WebMonitorExtension.EmptyWebMonitorExtension - org.apache.flink.runtime.webmonitor中的枚举
Empty web monitor extension which can be used as a null object.
WebMonitorUtils - org.apache.flink.runtime.webmonitor中的类
Utilities for the web runtime monitor.
WebMonitorUtils.LogFileLocation - org.apache.flink.runtime.webmonitor中的类
Singleton to hold the log and stdout file.
whenCompleteAsyncIfNotDone(CompletableFuture<IN>, Executor, BiConsumer<? super IN, ? super Throwable>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
This function takes a CompletableFuture and a bi-consumer to call on completion of this future.
withLocalState(T, T) - 类 中的静态方法org.apache.flink.runtime.state.SnapshotResult
 
WorkerDoneEvent - org.apache.flink.runtime.iterative.event中的类
Completion event sent from each IterationHead to the IterationSynchronizationSinkTask.
WorkerDoneEvent() - 类 的构造器org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerDoneEvent(int, String, Value) - 类 的构造器org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerDoneEvent(int, Map<String, Aggregator<?>>) - 类 的构造器org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerRegistration<WorkerType extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager.registration中的类
This class extends the TaskExecutorConnection, adding the worker information.
WorkerRegistration(TaskExecutorGateway, WorkerType, int, HardwareDescription) - 类 的构造器org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
workerStarted(ResourceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
Callback when a worker was started.
workerStarted(ResourceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
worksetAggregator - 类 中的变量org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
worksetBackChannel - 类 中的变量org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
WorksetEmptyConvergenceCriterion - org.apache.flink.runtime.iterative.convergence中的类
A workset iteration is by definition converged if no records have been updated in the solutionset.
WorksetEmptyConvergenceCriterion() - 类 的构造器org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
WorksetUpdateOutputCollector<T> - org.apache.flink.runtime.iterative.io中的类
A Collector to update the iteration workset (partial solution for bulk iterations).
WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>, Collector<T>) - 类 的构造器org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
wrapHook(MasterTriggerRestoreHook<T>, ClassLoader) - 类 中的静态方法org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Wraps a hook such that the user-code classloader is applied when the hook is invoked.
wrapSingleHandle(T) - 类 中的静态方法org.apache.flink.runtime.state.ChainedStateHandle
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.iterative.event.TerminationEvent
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
write(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[]) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(DataInputView, int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(T) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes a given record to this sort buffer.
write(T) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Writes a given record to this sort buffer.
write(T) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes a given record to this sort buffer.
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.plugable.SerializationDelegate
 
write(FSDataOutputStream) - 接口 中的方法org.apache.flink.runtime.state.BackendWritableBroadcastState
 
write(int) - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(byte[]) - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
write(int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
write(int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
write(FSDataOutputStream) - 类 中的方法org.apache.flink.runtime.state.HeapBroadcastState
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
write(int) - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(int) - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[]) - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(DataOutputView) - 类 中的方法org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
write(FSDataOutputStream) - 类 中的方法org.apache.flink.runtime.state.PartitionableListState
 
write(int) - 类 中的方法org.apache.flink.runtime.util.ForwardingOutputStream
 
write(byte[]) - 类 中的方法org.apache.flink.runtime.util.ForwardingOutputStream
 
write(byte[], int, int) - 类 中的方法org.apache.flink.runtime.util.ForwardingOutputStream
 
writeBack(BT) - 类 中的方法org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
writeBehindBuffers - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The queue of buffers that can be used for write-behind.
writeBehindBuffersAvailable - 类 中的变量org.apache.flink.runtime.operators.hash.MutableHashTable
The number of buffers in the write behind queue that are actually not write behind buffers, but regular buffers that only have not yet returned.
writeBlock(MemorySegment) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
Issues a asynchronous write request to the writer.
writeBlock(Buffer) - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
Writes the given block asynchronously.
writeBlock(T) - 接口 中的方法org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriterWithCallback
Writes the given block.
writeBoolean(boolean) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeByte(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeBytes(String) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeChar(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeChars(String) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeConfiguration(Configuration, File) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
Writes a Flink YAML config file from a Flink Configuration object.
writeDouble(double) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeElement(T, DataOutputView) - 接口 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner.ElementWriterFunction
This method defines how to write a single element to the output.
writeFloat(float) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeInt(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeIOMetricsAsJson(JsonGenerator) - 类 中的方法org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
Writes the IO metrics contained in this object to the given JsonGenerator.
writeLeaderInformation(UUID) - 类 中的方法org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Writes the current leader's address as well the given leader session ID to ZooKeeper.
writeLong(long) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeMemory - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
writeMemory - 类 中的变量org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory segments used to stage data to be written.
writeShort(int) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeStateInKeyGroup(DataOutputView, int) - 接口 中的方法org.apache.flink.runtime.state.StateSnapshot.StateKeyGroupWriter
Writes the data for the specified key-group to the output.
writeStateMetaInfoSnapshot(StateMetaInfoSnapshot, DataOutputView) - 接口 中的方法org.apache.flink.runtime.state.metainfo.StateMetaInfoWriter
Writes the given snapshot to the output view.
writeTo(ByteBuf) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
writeTo(ByteBuf) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
writeTo(ByteBuf) - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
writeToOutput(ChannelWriterOutputView) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
writeToOutput(ChannelWriterOutputView, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
 
writeToOutput(ChannelWriterOutputView, int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
writeToOutput(ChannelWriterOutputView, int, int) - 类 中的方法org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeUserArtifactEntriesToConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
 
writeUTF(String) - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
 

Y

YarnCancelJobTerminationHeaders - org.apache.flink.runtime.rest.messages中的类
已过时。
This should be removed once we can send arbitrary REST calls via the Yarn proxy.
YarnStopJobTerminationHeaders - org.apache.flink.runtime.rest.messages中的类
已过时。
This should be removed once we can send arbitrary REST calls via the Yarn proxy.

Z

ZooKeeperCheckpointIDCounter - org.apache.flink.runtime.checkpoint中的类
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperCheckpointIDCounter(CuratorFramework, String) - 类 的构造器org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
Creates a ZooKeeperCheckpointIDCounter instance.
ZooKeeperCheckpointRecoveryFactory - org.apache.flink.runtime.checkpoint中的类
ZooKeeperCheckpointRecoveryFactory(CuratorFramework, Configuration, Executor) - 类 的构造器org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
ZooKeeperCompletedCheckpointStore - org.apache.flink.runtime.checkpoint中的类
ZooKeeperCompletedCheckpointStore(int, ZooKeeperStateHandleStore<CompletedCheckpoint>, Executor) - 类 的构造器org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
ZooKeeperHaServices - org.apache.flink.runtime.highavailability.zookeeper中的类
An implementation of the HighAvailabilityServices using Apache ZooKeeper.
ZooKeeperHaServices(CuratorFramework, Executor, Configuration, BlobStoreService) - 类 的构造器org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
ZooKeeperLeaderElectionService - org.apache.flink.runtime.leaderelection中的类
Leader election service for multiple JobManager.
ZooKeeperLeaderElectionService(CuratorFramework, String, String) - 类 的构造器org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Creates a ZooKeeperLeaderElectionService object.
ZooKeeperLeaderRetrievalService - org.apache.flink.runtime.leaderretrieval中的类
The counterpart to the ZooKeeperLeaderElectionService.
ZooKeeperLeaderRetrievalService(CuratorFramework, String) - 类 的构造器org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
Creates a leader retrieval service which uses ZooKeeper to retrieve the leader information.
ZooKeeperModule - org.apache.flink.runtime.security.modules中的类
Responsible for installing a process-wide ZooKeeper security configuration.
ZooKeeperModule(SecurityConfiguration) - 类 的构造器org.apache.flink.runtime.security.modules.ZooKeeperModule
 
ZookeeperModuleFactory - org.apache.flink.runtime.security.modules中的类
ZookeeperModuleFactory() - 类 的构造器org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
 
ZooKeeperRunningJobsRegistry - org.apache.flink.runtime.highavailability.zookeeper中的类
A zookeeper based registry for running jobs, highly available.
ZooKeeperRunningJobsRegistry(CuratorFramework, Configuration) - 类 的构造器org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
ZooKeeperSharedCount - org.apache.flink.runtime.zookeeper中的类
Wrapper class for a SharedCount so that we don't expose a curator dependency in our internal APIs.
ZooKeeperSharedCount(SharedCount) - 类 的构造器org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
ZooKeeperSharedValue - org.apache.flink.runtime.zookeeper中的类
Wrapper class for a SharedValue so that we don't expose a curator dependency in our internal APIs.
ZooKeeperSharedValue(SharedValue) - 类 的构造器org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
ZooKeeperStateHandleStore<T extends Serializable> - org.apache.flink.runtime.zookeeper中的类
Class which stores state via the provided RetrievableStateStorageHelper and writes the returned state handle to ZooKeeper.
ZooKeeperStateHandleStore(CuratorFramework, RetrievableStateStorageHelper<T>) - 类 的构造器org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
ZooKeeperSubmittedJobGraphStore - org.apache.flink.runtime.jobmanager中的类
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperSubmittedJobGraphStore(String, ZooKeeperStateHandleStore<SubmittedJobGraph>, PathChildrenCache) - 类 的构造器org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Submitted job graph store backed by ZooKeeper.
ZooKeeperUtilityFactory - org.apache.flink.runtime.zookeeper中的类
Creates ZooKeeper utility classes without exposing the CuratorFramework dependency.
ZooKeeperUtilityFactory(Configuration, String) - 类 的构造器org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
 
ZooKeeperUtils - org.apache.flink.runtime.util中的类
Class containing helper functions to interact with ZooKeeper.
ZooKeeperUtils.SecureAclProvider - org.apache.flink.runtime.util中的类
Secure ACLProvider implementation.
ZooKeeperUtils.ZkClientACLMode - org.apache.flink.runtime.util中的枚举
ZooKeeper client ACL mode enum.
ZooKeeperVersionedValue<T> - org.apache.flink.runtime.zookeeper中的类
Wrapper class for a VersionedValue so that we don't expose a curator dependency in our internal APIs.
ZooKeeperVersionedValue(VersionedValue<T>) - 类 的构造器org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
 

_

_getByte(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getInt(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getIntLE(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getLong(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getLongLE(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getShort(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getShortLE(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getUnsignedMedium(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_getUnsignedMediumLE(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setByte(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setInt(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setIntLE(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setLong(int, long) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setLongLE(int, long) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setMedium(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setMediumLE(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setShort(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
_setShortLE(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 
跳过导航链接

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