- abort(CheckpointFailureReason, Throwable) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts a checkpoint with reason and cause.
- abort(CheckpointFailureReason) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts a checkpoint with reason and cause.
- 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
.
- abortPendingCheckpoints(CheckpointException) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Aborts all the pending checkpoints due to en exception.
- 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中的类
-
- AbstractAggregatedMetricsHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- AbstractAggregatedMetricsParameters<M extends MessageQueryParameter<?>> - org.apache.flink.runtime.rest.messages.job.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
-
- AbstractBuffersUsageGauge - org.apache.flink.runtime.io.network.metrics中的类
-
Abstract gauge implementation for calculating the buffer usage percent.
- AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - org.apache.flink.runtime.operators中的类
-
- AbstractCachedBuildSideJoinDriver(int, int) - 类 的构造器org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- AbstractChannelReaderInputView - org.apache.flink.runtime.io.disk.iomanager中的类
-
A
DataInputView
that is backed by a
FileIOChannel
, making it effectively a data input stream.
- AbstractChannelReaderInputView(int) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
-
- AbstractChannelWriterOutputView - org.apache.flink.runtime.io.disk.iomanager中的类
-
A
DataOutputView
that is backed by a
FileIOChannel
,
making it effectively a data output stream.
- AbstractChannelWriterOutputView(int, int) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
- 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.
- AbstractEvent - org.apache.flink.runtime.event中的类
-
This type of event can be used to exchange notification messages between
different
TaskExecutor
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中的类
-
- 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中的类
-
- 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, ExecutionConfig, TtlTimeProvider, CloseableRegistry, InternalKeyContext<K>) - 类 的构造器org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, ExecutionConfig, TtlTimeProvider, CloseableRegistry, StreamCompressionDecorator, InternalKeyContext<K>) - 类 的构造器org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- AbstractKeyedStateBackendBuilder<K> - org.apache.flink.runtime.state中的类
-
- 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
-
- AbstractPartitionTracker<K,M> - org.apache.flink.runtime.io.network.partition中的类
-
Base partition tracker implementation, providing underlying data-structures for storing partitions, their associated
keys and meta-information.
- AbstractPartitionTracker() - 类 的构造器org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- AbstractTaskManagerFileHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - 类 的构造器org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- AbstractUserClassPathJobGraphRetriever - org.apache.flink.runtime.entrypoint.component中的类
-
Abstract class for the JobGraphRetriever which supports getting user classpaths.
- AbstractUserClassPathJobGraphRetriever(File) - 类 的构造器org.apache.flink.runtime.entrypoint.component.AbstractUserClassPathJobGraphRetriever
-
- 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中的接口
-
- AccessExecutionJobVertex - org.apache.flink.runtime.executiongraph中的接口
-
- AccessExecutionVertex - org.apache.flink.runtime.executiongraph中的接口
-
- 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中的类
-
- 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.scheduler.SchedulerBase
-
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
-
- 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
-
- acknowledgeMasterState(String, MasterState) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Acknowledges a master state (state generated on the checkpoint coordinator) to
the pending checkpoint.
- acknowledgeTask(ExecutionAttemptID, TaskStateSnapshot, CheckpointMetrics) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Acknowledges the task with the given execution attempt id and the given subtask state.
- acquireLease() - 类 中的方法org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
-
Returns a ResourceGuard.Lease
that prevents closing this stream.
- ActiveResourceManager<WorkerType extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager中的类
-
Base class for
ResourceManager
implementations which contains some common variables and methods.
- ActiveResourceManager(Configuration, Map<String, String>, RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup) - 类 的构造器org.apache.flink.runtime.resourcemanager.ActiveResourceManager
-
- ActiveResourceManagerFactory<T extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager中的类
-
Resource manager factory which creates active
ResourceManager
implementations.
- ActiveResourceManagerFactory() - 类 的构造器org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- ActorSystemScheduledExecutorAdapter - org.apache.flink.runtime.concurrent.akka中的类
-
- ActorSystemScheduledExecutorAdapter(ActorSystem) - 类 的构造器org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- actualModVersion() - 异常错误 中的方法org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
-
- AdaptedRestartPipelinedRegionStrategyNG - org.apache.flink.runtime.executiongraph.failover中的类
-
This failover strategy uses flip1.RestartPipelinedRegionStrategy to make task failover decisions.
- AdaptedRestartPipelinedRegionStrategyNG(ExecutionGraph) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- AdaptedRestartPipelinedRegionStrategyNG.Factory - org.apache.flink.runtime.executiongraph.failover中的类
-
Factory that instantiates the AdaptedRestartPipelinedRegionStrategyNG.
- 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(T) - 类 中的方法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
-
- addBufferConsumer(BufferConsumer, int) - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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
-
- 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
-
- addExtendedResource(String, Resource) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- addExtendedResources(Map<String, Resource>) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- 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
-
- addInputFormat(OperatorID, InputFormat<?, ?>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- addInputFormat(OperatorID, UserCodeWrapper<? extends InputFormat<?, ?>>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- addInputFormat(OperatorID, UserCodeWrapper<? extends InputFormat<?, ?>>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- addInputToGroup(int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- 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.
- addJars(List<URL>) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
-
- 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.
- addMetric(String, Metric, AbstractMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricQueryService
-
- 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.
- addOptions(String, T) - 类 中的方法org.apache.flink.runtime.rest.handler.router.Router
-
- addOutputFormat(OperatorID, OutputFormat<?>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- addOutputFormat(OperatorID, UserCodeWrapper<? extends OutputFormat<?>>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- addOutputFormat(OperatorID, UserCodeWrapper<? extends OutputFormat<?>>) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- addOutputShipStrategy(ShipStrategyType) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- addParameters(OperatorID, Configuration) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- addParameters(OperatorID, String, String) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- 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.
- 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(T) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Add the given task to the slot identified by the task's allocation id.
- addTask(T) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- 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
-
- 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, ResourceSpec) - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- adjustForLocalExecution(Configuration) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
-
- 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.io.disk.iomanager.HeaderlessChannelReaderInputView
-
- 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中的类
-
- AggregatedMetricsResponseBody.Serializer - org.apache.flink.runtime.rest.messages.job.metrics中的类
-
- 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
-
- 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
-
- 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中的类
-
- AkkaRpcService(ActorSystem, AkkaRpcServiceConfiguration) - 类 的构造器org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- AkkaRpcServiceConfiguration - org.apache.flink.runtime.rpc.akka中的类
-
- 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
-
- 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
-
- 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
-
- allocateBatchSlot(SlotRequestId, ScheduledUnit, SlotProfile) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- allocateBatchSlot(SlotRequestId, ScheduledUnit, SlotProfile) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
Allocating batch slot with specific requirement.
- 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, Collection<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
-
- 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
- allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile) - 类 中的方法org.apache.flink.runtime.executiongraph.SlotProviderStrategy
-
Allocating slot with specific requirement.
- allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
Allocating slot with specific requirement.
- allocateSlot(ScheduledUnit, 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.
- allocateSlot(int, JobID, AllocationID, ResourceProfile, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Allocate the slot with the given index for the given job and allocation id.
- allocateSlot(int, JobID, AllocationID, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- allocateSlot(int, JobID, AllocationID, ResourceProfile, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- allocateSlotsAndDeploy(List<ExecutionVertexDeploymentOption>) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultScheduler
-
- allocateSlotsAndDeploy(List<ExecutionVertexDeploymentOption>) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerOperations
-
Allocate slots and deploy the vertex when slots are returned.
- allocateSlotsFor(List<ExecutionVertexSchedulingRequirements>) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator
-
- allocateSlotsFor(List<ExecutionVertexSchedulingRequirements>) - 接口 中的方法org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Allocate slots for the given executions.
- 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
-
- ANY - 类 中的静态变量org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
A ResourceProfile that indicates infinite resource that matches any resource requirement, for testability purpose only.
- AnyMatchingSlotMatchingStrategy - org.apache.flink.runtime.resourcemanager.slotmanager中的枚举
-
- 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
-
- 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
-
- 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.
- applyWithShuffleTypeCheck(Class<SD>, ShuffleDescriptor, Function<UnknownShuffleDescriptor, T>, Function<SD, T>) - 类 中的静态方法org.apache.flink.runtime.shuffle.ShuffleUtils
-
- archive() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- archive() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- archive() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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, String) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- ArchivedExecutionGraphStore - org.apache.flink.runtime.dispatcher中的接口
-
- ArchivedExecutionJobVertex - org.apache.flink.runtime.executiongraph中的类
-
- ArchivedExecutionJobVertex(ExecutionJobVertex) - 类 的构造器org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, ResourceProfile, 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
-
- 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
ArchivedJson
s containing JSON responses and their respective REST URL
for a given job.
- archiveJsonWithPath(AccessExecutionGraph) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- areMasterStatesFullyAcknowledged() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- areTasksFullyAcknowledged() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- 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中的类
-
- 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, Time) - 类 中的方法org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- asList() - 类 中的方法org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- assertNoException(CompletableFuture<?>) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
-
- 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.rpc.RpcEndpoint.MainThreadExecutor
-
- assignExclusiveSegments() - 类 中的方法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.resourcemanager.slotmanager.PendingTaskManagerSlot
-
- assignPendingSlotRequest(PendingSlotRequest) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- 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中的类
-
- 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中的类
-
- 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
-
- AvailabilityHelper() - 类 的构造器org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
- availabilityHelper - 类 中的变量org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- AvailabilityProvider - org.apache.flink.runtime.io中的接口
-
Interface defining couple of essential methods for listening on data availability using
CompletableFuture
.
- AvailabilityProvider.AvailabilityHelper - org.apache.flink.runtime.io中的类
-
A availability implementation for providing the helpful functions of resetting the
available/unavailable states.
- AVAILABLE - 接口 中的静态变量org.apache.flink.runtime.io.AvailabilityProvider
-
- available() - 类 中的方法org.apache.flink.runtime.state.BoundedInputStream
-
- available() - 类 中的方法org.apache.flink.runtime.util.ForwardingInputStream
-
- availableMemory() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Returns the total size of the certain type of memory handled by this memory manager.
- 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
-
- cachable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- cachable - 类 中的变量org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- calculateCandidateScore(int, int, double) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- calculateHeapSize(int, Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
-
Calculate heap size after cut-off.
- calculatePreferredLocations(LocationPreferenceConstraint) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
Calculates the preferred locations based on the location preference constraint.
- calculateTotalBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - 类 中的方法org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
-
- 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.
- canBeCompressed(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Whether the buffer can be compressed or not.
- 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.heartbeat.HeartbeatMonitor
-
Cancel this monitor.
- cancel() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- 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(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator
-
- cancel(ExecutionVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Cancel an ongoing slot request.
- cancel() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- cancel() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- cancel(boolean) - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
-
- cancel() - 类 中的方法org.apache.flink.runtime.state.AsyncSnapshotCallable
-
- cancel(boolean) - 类 中的方法org.apache.flink.runtime.state.DoneFuture
-
- cancelChainedTasks(List<ChainedDriver<?, ?>>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
-
- 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
-
- cancelConsumption() - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
Cancel the partition consumptions as a result of state check.
- cancelExecution() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- cancelJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- cancelJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- 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.executiongraph.SlotProviderStrategy
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
- 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.
- 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.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.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
-
- cancelTasks(Set<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- 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.failover.flip1.FailureHandlingResult
-
Returns whether the restarting can be conducted.
- canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- canRestart() - 枚举 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.NoRestartBackoffTimeStrategy
-
- canRestart() - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy
-
Returns whether a restart should be conducted.
- 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
.
- canRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy
-
- 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(AbstractChannelReaderInputView, 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.
- ChannelSelectorRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
-
A regular record-oriented runtime result writer.
- 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.
- check(SchedulingExecutionVertex<?, ?>) - 类 中的方法org.apache.flink.runtime.scheduler.strategy.InputDependencyConstraintChecker
-
- checkBatchSlotTimeout() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- checkConfigParameter(boolean, Object, String, String) - 类 中的静态方法org.apache.flink.runtime.util.ConfigurationParserUtils
-
Validates a condition for a config parameter and displays a standard exception, if the
the condition does not hold.
- checkErroneous() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Checks the exception state of this channel.
- checkErroneous() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- checkError() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Checks for an error and rethrows it if one was reported.
- checkExit(int) - 类 中的方法org.apache.flink.runtime.security.ExitTrappingSecurityManager
-
- checkFailureCounter(CheckpointException, long) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
- checkIdleSlot() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Check the available slots, release the slot that is idle for a long time.
- 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
-
- checkPermission(Permission) - 类 中的方法org.apache.flink.runtime.security.ExitTrappingSecurityManager
-
- 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中的类
-
- CheckpointConfigInfo - org.apache.flink.runtime.rest.messages.checkpoints中的类
-
- CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode, long, long, long, int, CheckpointConfigInfo.ExternalizedCheckpointInfo, String) - 类 的构造器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, CheckpointCoordinatorConfiguration, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, ScheduledExecutor, SharedStateRegistryFactory, CheckpointFailureManager) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- CheckpointCoordinator(JobID, CheckpointCoordinatorConfiguration, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, ScheduledExecutor, SharedStateRegistryFactory, CheckpointFailureManager, Clock) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- CheckpointCoordinatorConfiguration - org.apache.flink.runtime.jobgraph.tasks中的类
-
- CheckpointCoordinatorConfiguration(long, long, long, int, CheckpointRetentionPolicy, boolean, boolean, int) - 类 的构造器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中的接口
-
- 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(CheckpointFailureReason) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(String, CheckpointFailureReason) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(CheckpointFailureReason, Throwable) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(String, CheckpointFailureReason, Throwable) - 异常错误 的构造器org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointFailureManager - org.apache.flink.runtime.checkpoint中的类
-
The checkpoint failure manager which centralized manage checkpoint failure processing logic.
- CheckpointFailureManager(int, CheckpointFailureManager.FailJobCallback) - 类 的构造器org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
- CheckpointFailureManager.FailJobCallback - org.apache.flink.runtime.checkpoint中的接口
-
A callback interface about how to fail a job.
- CheckpointFailureReason - org.apache.flink.runtime.checkpoint中的枚举
-
Various reasons why a checkpoint was failure.
- 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中的类
-
- 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中的接口
-
Implementations of this interface should implement methods acting as an administration role for checkpoint storage,
which defined in
CheckpointStorageCoordinatorView
.
- CheckpointStorageCoordinatorView - org.apache.flink.runtime.state中的接口
-
- 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.
- CheckpointStorageWorkerView - org.apache.flink.runtime.state中的接口
-
This interface implements the durable storage of checkpoint data and metadata streams.
- 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中的类
-
- 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中的类
-
- CheckpointStreamWithResultProvider.PrimaryStreamOnly - org.apache.flink.runtime.state中的类
-
- CheckpointType - org.apache.flink.runtime.checkpoint中的枚举
-
The type of checkpoint to perform.
- checkStateMetaInfo(StateDescriptor<?, ?>) - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- childFirst(URL[], ClassLoader, String[], Consumer<Throwable>) - 类 中的静态方法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.
- 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.DefaultExecutionGraphCache
-
- cleanup() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Perform the cleanup of out dated cache entries.
- 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.jobmaster.slotpool.DualKeyLinkedMap
-
- 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.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.BroadcastRecordWriter
-
- clearBuffers() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
-
- clearBuffers() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- 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.resourcemanager.slotmanager.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.
- clearWriters(List<RecordWriter<?>>) - 类 中的静态方法org.apache.flink.runtime.operators.BatchTask
-
- ClientHighAvailabilityServices - org.apache.flink.runtime.highavailability中的接口
-
ClientHighAvailabilityServices
provides services those are required
on client-side.
- 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
-
- 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.nonha.standalone.StandaloneClientHAServices
-
- close() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperClientHAServices
-
- close() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- close() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelInputView
-
- close() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
Remove all the temp directories.
- 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.AbstractChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer
- 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.IOManager
-
Removes all temporary files.
- close() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Close method.
- 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.MultipleRecordWriters
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Closes the writer.
- close() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- close(RemoteInputChannel) - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Tries to shut down all network I/O components.
- close() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- close() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- close(RemoteInputChannel) - 接口 中的方法org.apache.flink.runtime.io.network.PartitionRequestClient
-
Cancels the partition request for the given remote input channel and removes
this client from factory if it is not referenced by any other input channels.
- close() - 类 中的方法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.memory.OpaqueMemoryResource
-
Releases this resource.
- 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.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.SlotManagerImpl
-
Closes the slot manager.
- close() - 类 中的方法org.apache.flink.runtime.rest.handler.FileUploads
-
- close() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
-
- close() - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Closes the execution graph cache.
- 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.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- close() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- 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.dispatcher.runner.DefaultDispatcherRunner
-
- closeAsync() - 枚举 中的方法org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- closeAsync() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- closeAsync() - 类 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
- closeAsync() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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.slot.TaskSlot
-
- closeAsync() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- closeAsync() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- closeAsync() - 枚举 中的方法org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
- closeBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
-
- closeBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
-
- 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.
- closeExceptionally() - 类 中的方法org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- 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.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中的类
-
- ClusterConfigurationInfoEntry(String, String) - 类 的构造器org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- ClusterConfigurationInfoHeaders - org.apache.flink.runtime.rest.messages中的类
-
- 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中的枚举
-
- ClusterEntrypointException - org.apache.flink.runtime.entrypoint中的异常错误
-
- 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
-
- ClusterEntrypointUtils - org.apache.flink.runtime.util中的类
-
- 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中的类
-
- 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中的类
-
- 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
-
- ClusterPartitionReport - org.apache.flink.runtime.taskexecutor.partition中的类
-
A report about the current status of all cluster partitions of the TaskExecutor, describing
which partitions are available.
- ClusterPartitionReport(Collection<ClusterPartitionReport.ClusterPartitionReportEntry>) - 类 的构造器org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport
-
- ClusterPartitionReport.ClusterPartitionReportEntry - org.apache.flink.runtime.taskexecutor.partition中的类
-
An entry describing all partitions belonging to one dataset.
- ClusterPartitionReportEntry(IntermediateDataSetID, Set<ResultPartitionID>, int) - 类 的构造器org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
-
- 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.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
-
- 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(int, int, int, int) - 接口 中的方法org.apache.flink.runtime.operators.sort.IndexedSortable
-
- 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(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
-
- completeAllocation(AllocationID, JobID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.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中的接口
-
- completedExceptionally(Throwable) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
-
- CompletedSubtaskCheckpointStatistics(int, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment) - 类 的构造器org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- completedVoidFuture() - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
-
Returns a completed future of type
Void
.
- 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.
- 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
StateBackend
s and some other
components in tasks.
- compress(ByteBuffer, int, int, ByteBuffer, int) - 接口 中的方法org.apache.flink.runtime.io.compression.BlockCompressor
-
Compress source data read from (
Buffer.position()
+
srcOff
),
and write the compressed data to dst.
- compress(byte[], int, int, byte[], int) - 接口 中的方法org.apache.flink.runtime.io.compression.BlockCompressor
-
Compress data read from src, and write the compressed data to dst.
- compress(ByteBuffer, int, int, ByteBuffer, int) - 类 中的方法org.apache.flink.runtime.io.compression.Lz4BlockCompressor
-
- compress(byte[], int, int, byte[], int) - 类 中的方法org.apache.flink.runtime.io.compression.Lz4BlockCompressor
-
- compressToIntermediateBuffer(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferCompressor
-
- compressToOriginalBuffer(Buffer) - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferCompressor
-
- 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 corresponding to the fraction of all memory governed by this MemoryManager.
- 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.
- computePipelinedRegions(Topology<?, ?, V, R>) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.flip1.PipelinedRegionComputeUtil
-
- 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.
- ConfigurationParserUtils - org.apache.flink.runtime.util中的类
-
Utility class to extract related parameters from Configuration
and to
sanity check them.
- ConfigurationParserUtils() - 类 的构造器org.apache.flink.runtime.util.ConfigurationParserUtils
-
- 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(ContainerSpecification) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.UserLibOverlay
-
- 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.
- confirmLeadership(UUID, String) - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Confirms that the
LeaderContender
has accepted the leadership identified by the
given leader session id.
- confirmLeadership(UUID, String) - 类 中的方法org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- confirmLeadership(UUID, String) - 类 中的方法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.
- 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中的类
-
- 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
-
- CONSERVATIVE_PAGE_SIZE_MULTIPLE - 类 中的静态变量org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
A conservative fallback value (64 KiBytes) that should be a multiple of the page size even
in some uncommon cases of servers installations with larger-than-usual page sizes.
- ConstantTextHandler - 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.
- ConsumableNotifyingResultPartitionWriterDecorator - org.apache.flink.runtime.taskmanager中的类
-
A wrapper of result partition writer for handling the logic of consumable notification.
- ConsumableNotifyingResultPartitionWriterDecorator(TaskActions, JobID, ResultPartitionWriter, ResultPartitionConsumableNotifier) - 类 的构造器org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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(TaskExecutorProcessSpec, 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(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- 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
-
- containsCoLocationConstraints() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
-
- containsCoLocationConstraints() - 类 中的方法org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
-
- containsCoLocationConstraints() - 接口 中的方法org.apache.flink.runtime.topology.Topology
-
Returns whether the topology contains co-location constraints.
- 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(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- containsKey(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- containsKey(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Returns whether this map contains the specified key/namespace composite key.
- 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.DualKeyLinkedMap
-
- containsKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- 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.job.UpperLimitExceptionParameter
-
- 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
-
- 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(Integer) - 类 中的方法org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
-
- 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
-
- copyFromSerializerToTargetChannel(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- CopyOnWriteStateMap<K,N,S> - org.apache.flink.runtime.state.heap中的类
-
Implementation of Flink's in-memory state maps with copy-on-write support.
- CopyOnWriteStateMap.StateMapEntry<K,N,S> - org.apache.flink.runtime.state.heap中的类
-
- CopyOnWriteStateMapSnapshot<K,N,S> - org.apache.flink.runtime.state.heap中的类
-
- CopyOnWriteStateTable<K,N,S> - org.apache.flink.runtime.state.heap中的类
-
- 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.
- 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.
- copyWithReaderPosition(int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns a retained copy with separate indexes and sets the reader position to the given value.
- CorruptConfigurationException - 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, TaskExecutorProcessSpec, int) - 类 中的静态方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Computes the parameters to be used to start a TaskManager Java process.
- create() - 接口 中的方法org.apache.flink.runtime.dispatcher.JobManagerMetricGroupFactory
-
- create(LeaderElectionService, FatalErrorHandler, DispatcherLeaderProcessFactory) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
-
- create(UUID) - 接口 中的方法org.apache.flink.runtime.dispatcher.runner.DispatcherLeaderProcessFactory
-
- create(UUID) - 类 中的方法org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactory
-
- create(JobGraphRetriever) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactoryFactory
-
- create(UUID, AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory, JobGraphStore, Executor, FatalErrorHandler) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
-
- create(DispatcherFactory) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactoryFactory
-
- create(Configuration, Executor, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, ArchivedExecutionGraphStore, MetricQueryServiceRetriever, FatalErrorHandler) - 类 中的方法org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
-
- create(Configuration, Executor, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, ArchivedExecutionGraphStore, MetricQueryServiceRetriever, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponentFactory
-
- create(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[], Consumer<Throwable>) - 类 中的静态方法org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG.Factory
-
- create(ExecutionGraph) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
-
Instantiates the FailoverStrategy
.
- create(FailoverTopology<?, ?>, ResultPartitionAvailabilityChecker) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailoverStrategy.Factory
-
- create() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory
-
- create() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory
-
- create() - 枚举 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
-
- create(FailoverTopology<?, ?>, ResultPartitionAvailabilityChecker) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartAllStrategy.Factory
-
- create() - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy.Factory
-
- create(FailoverTopology<?, ?>, ResultPartitionAvailabilityChecker) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy.Factory
-
- create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.NoOpFailoverStrategy.Factory
-
- create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
-
- create(ExecutionGraph) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
-
- create(int, ResultPartition, File, int) - 枚举 中的方法org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Creates BoundedBlockingSubpartition of this type.
- create(String, InputGateDeploymentDescriptor, PartitionProducerStateProvider, InputChannelMetrics) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
-
Creates an input gate and all of its input channels.
- create(PartitionTrackerFactory.TaskExecutorGatewayLookup) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionTrackerFactory
-
Creates a new PartitionTracker.
- create(String, ResultPartitionDeploymentDescriptor) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- create(String, ResultPartitionID, ResultPartitionType, int, int, FunctionWithException<BufferPoolOwner, BufferPool, IOException>) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- create() - 类 中的方法org.apache.flink.runtime.jobmanager.HaServicesJobGraphStoreFactory
-
- create() - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphStoreFactory
-
- 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() - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
- create(SlotSelectionStrategy) - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
- create(Collection<JobStatus>) - 类 中的静态方法org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- create(MetricRegistry, String) - 类 中的静态方法org.apache.flink.runtime.metrics.groups.ProcessMetricGroup
-
- create(MetricRegistry, String) - 类 中的静态方法org.apache.flink.runtime.metrics.groups.ResourceManagerMetricGroup
-
- create(List<MemorySegment>) - 类 中的方法org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
-
- create(List<MemorySegment>) - 接口 中的方法org.apache.flink.runtime.operators.sort.InMemorySorterFactory
-
- create(AccessExecution, MetricFetcher, JobID, JobVertexID) - 类 中的静态方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- create(TaskManagerLocation, ExecutionAttemptID) - 类 中的静态方法org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- 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
-
- createActivatorDeactivator() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- createActiveResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup) - 类 中的方法org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- createActiveResourceManagerConfiguration(Configuration) - 类 中的静态方法org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- 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
-
- createBlockCompressionFactory(String) - 接口 中的静态方法org.apache.flink.runtime.io.compression.BlockCompressionFactory
-
- createBufferConsumer() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
This method always creates a
BufferConsumer
starting from the current writer offset.
- 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, BufferPoolOwner) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool with an owner, which is guaranteed to provide at least the
number of required buffers.
- createBufferPool(int, int) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- createBufferPool(int, int, 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.FileChannelManager
-
Creates an ID identifying an underlying file channel and returns it.
- createChannel() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- createChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createChannelEnumerator() - 接口 中的方法org.apache.flink.runtime.io.disk.FileChannelManager
-
Creates an enumerator for channels that logically belong together and returns it.
- createChannelEnumerator() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- 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
-
- 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
-
- 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
-
- 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
-
- createClientHAService(Configuration) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
- createClientHAServices(Configuration) - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesFactory
-
- createClientSSLEngineFactory() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createClusterPartitionReport() - 接口 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
- createClusterPartitionReport() - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
-
- 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
-
- createDefault() - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- createDefaultWorkerSlotProfiles(TaskExecutorProcessSpec, int) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- createDeploymentDescriptor(AllocationID, int, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>) - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
- createDetailsForJob(AccessExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, PartialDispatcherServicesWithJobGraphStore) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherFactory
-
- createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, PartialDispatcherServicesWithJobGraphStore) - 枚举 中的方法org.apache.flink.runtime.dispatcher.JobDispatcherFactory
-
- createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, PartialDispatcherServicesWithJobGraphStore) - 枚举 中的方法org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
- 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
-
- createDispatcherRunner(LeaderElectionService, FatalErrorHandler, JobGraphStoreFactory, Executor, RpcService, PartialDispatcherServices) - 类 中的方法org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
-
- createDispatcherRunner(LeaderElectionService, FatalErrorHandler, JobGraphStoreFactory, Executor, RpcService, PartialDispatcherServices) - 接口 中的方法org.apache.flink.runtime.dispatcher.runner.DispatcherRunnerFactory
-
- createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalRecoveryDirectoryProvider) - 接口 中的静态方法org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- createDynamicProperty(String, String) - 类 中的静态方法org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Create a dynamic property from the given key and value of the format -Dkey=value
.
- createEvenlySpreadOut() - 类 中的静态方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- createExecutionGraphCache(RestHandlerConfiguration) - 接口 中的静态方法org.apache.flink.runtime.rest.RestEndpointFactory
-
- createExecutorService(int, int, String) - 类 中的静态方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- createFactory(JobGraphStoreFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.dispatcher.runner.DispatcherLeaderProcessFactoryFactory
-
- createFactory(JobGraphStoreFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - 类 中的方法org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactoryFactory
-
- createFactory(JobGraphStoreFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - 类 中的方法org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactoryFactory
-
- createFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- createFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- 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.
- createFileSystemStateStorage(Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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, File) - 类 中的静态方法org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
-
- createFrom(ExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- createFrom(AccessExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.jobmaster.JobResult
-
- 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
-
- 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.
- createHeartbeatMonitor(ResourceID, HeartbeatTarget<O>, ScheduledExecutor, HeartbeatListener<?, O>, long) - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitor.Factory
-
Create heartbeat monitor heartbeat monitor.
- 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, Executor) - 接口 中的静态方法org.apache.flink.runtime.dispatcher.HistoryServerArchivist
-
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, Collection<InputGateDeploymentDescriptor>) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, Collection<InputGateDeploymentDescriptor>) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Factory method for the
InputGates
to consume result partitions.
- createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
- createInstance(SchedulingTopology<?, ?>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.NotReleasingPartitionReleaseStrategy.Factory
-
- createInstance(SchedulingTopology<?, ?>) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PartitionReleaseStrategy.Factory
-
- createInstance(SchedulingTopology<?, ?>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy.Factory
-
- createInstance(InputsLocationsRetriever) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocatorFactory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, JobMasterPartitionTracker) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultSchedulerFactory
-
- createInstance(InputsLocationsRetriever) - 接口 中的方法org.apache.flink.runtime.scheduler.ExecutionSlotAllocatorFactory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, JobMasterPartitionTracker) - 类 中的方法org.apache.flink.runtime.scheduler.LegacySchedulerFactory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, JobMasterPartitionTracker) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNGFactory
-
- createInstance(SchedulerOperations, SchedulingTopology<?, ?>) - 类 中的方法org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy.Factory
-
- createInstance(SchedulerOperations, SchedulingTopology<?, ?>) - 类 中的方法org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy.Factory
-
- createInstance(SchedulerOperations, SchedulingTopology<?, ?>) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingStrategyFactory
-
- 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
-
- createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateFactory
-
- createJobComponentFactory(ResourceManagerFactory<?>, JobGraphRetriever) - 类 中的静态方法org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
-
- createJobGraphs(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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
-
- createJobRunner(JobGraphRetriever) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
-
- 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
-
- 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.taskexecutor.KvStateService
-
- createLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderElectionService(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderElectionService(CuratorFramework, Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderRetrievalService(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, boolean, String) - 类 中的静态方法org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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
-
- createMetricQueryService(RpcService, ResourceID, long) - 类 中的静态方法org.apache.flink.runtime.metrics.dump.MetricQueryService
-
Starts the MetricQueryService actor in the given actor system.
- 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
-
- createModule(SecurityConfiguration) - 类 中的方法org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
-
- createNettySSLHandler(ByteBufAllocator) - 类 中的方法org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
-
- createNettySSLHandler(ByteBufAllocator, 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
-
- 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
-
- 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
-
- 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
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup) - 类 中的方法org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup) - 枚举 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
-
- createRestartBackoffTimeStrategyFactory(RestartStrategies.RestartStrategyConfiguration, Configuration, boolean) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategyFactoryLoader
-
- 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
.
- createRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy.ThrowingRestartStrategyFactory
-
- createRestartStrategyFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- createRestClientSSLEngineFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 枚举 中的方法org.apache.flink.runtime.rest.JobRestEndpointFactory
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 接口 中的方法org.apache.flink.runtime.rest.RestEndpointFactory
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - 枚举 中的方法org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
- createRestNettySSLContext(Configuration, boolean, ClientAuth, SslProvider) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for the external REST SSL.
- createRestServerSSLEngineFactory(Configuration) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
-
- createRestSSLContext(Configuration, boolean) - 类 中的静态方法org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for clients against the external REST endpoint.
- 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.
- createResultPartitionWriters(ShuffleIOOwnerContext, Collection<ResultPartitionDeploymentDescriptor>) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createResultPartitionWriters(ShuffleIOOwnerContext, Collection<ResultPartitionDeploymentDescriptor>) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
- 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(String, String, Configuration, String, BootstrapTools.ActorSystemExecutorConfiguration) - 类 中的静态方法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.
- createSchedulerNGFactory(Configuration, RestartStrategyFactory) - 类 中的静态方法org.apache.flink.runtime.dispatcher.SchedulerNGFactoryFactory
-
- 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
-
- createSessionComponentFactory(ResourceManagerFactory<?>) - 类 中的静态方法org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
-
- createSessionRunner(DispatcherFactory) - 类 中的静态方法org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
-
- createSharedCount(String, int) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- 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
-
- createShuffleEnvironment(ShuffleEnvironmentContext) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
-
- createShuffleEnvironment(ShuffleEnvironmentContext) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
- createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Create a context of the shuffle input/output owner used to create partitions or gates belonging to the owner.
- createShuffleIOOwnerMetricGroup(MetricGroup) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- createShuffleMaster(Configuration) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
-
- createShuffleMaster(Configuration) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
Factory method to create a specific
ShuffleMaster
implementation.
- 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
-
- createSlotReport(ResourceID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- 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
-
- createStateMap() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- createStateMap() - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- createStateMap() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- createSubpartitionView(int, BufferAvailabilityListener) - 类 中的方法org.apache.flink.runtime.io.network.partition.ReleaseOnConsumptionResultPartition
-
- 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.CheckpointStorageWorkerView
-
Opens a stream to persist checkpoint state data that is owned strictly by tasks and
not attached to the life cycle of a specific checkpoint.
- createTaskOwnedStateStream() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- createTaskOwnedStateStream() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- createTaskRegistry(JobID, JobVertexID) - 类 中的方法org.apache.flink.runtime.query.KvStateRegistry
-
- 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.
- createUnregisteredJobManagerJobMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredJobManagerMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredOperatorMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredProcessMetricGroup() - 类 中的静态方法org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredResourceManagerMetricGroup() - 类 中的静态方法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
-
- createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- CreditBasedInputBuffersUsageGauge - org.apache.flink.runtime.io.network.metrics中的类
-
Gauge metric measuring the input buffers usage for
SingleInputGate
s under credit based mode.
- CreditBasedInputBuffersUsageGauge(FloatingBuffersUsageGauge, ExclusiveBuffersUsageGauge, SingleInputGate[]) - 类 的构造器org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- 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
-
- 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
-
- 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
-
- 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中的接口
-
- 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
-
- generateDefaultSlotResourceProfile(TaskExecutorProcessSpec, int) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- generateDynamicConfigsStr(TaskExecutorProcessSpec) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- generateDynamicSlotID(ResourceID) - 类 中的静态方法org.apache.flink.runtime.clusterframework.types.SlotID
-
Generate a SlotID without actual slot index for dynamic slot allocation.
- generateEndpointIdWithUUID() - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherFactory
-
- generateEndpointIdWithUUID() - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
- generateJvmParametersStr(TaskExecutorProcessSpec) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- 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.
- generateTotalAvailableResourceProfile(TaskExecutorProcessSpec) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- generateZookeeperPath(String, String) - 类 中的静态方法org.apache.flink.runtime.util.ZooKeeperUtils
-
- GenericKeyMetricGroup - org.apache.flink.runtime.metrics.groups中的类
-
- 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中的类
-
- 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.checkpoint.CheckpointIDCounter
-
Atomically gets the current checkpoint ID.
- get() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- get() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- 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(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.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.CopyOnWriteStateMap
-
- get(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- get(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Returns the state for the composite of active key and given namespace.
- 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.
- getActiveSlots(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getActorSystem() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- 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.TaskManagerGateway
-
Return the address of the task manager with which the gateway is associated.
- 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.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.shuffle.ProducerDescriptor
-
- getAddress() - 类 中的方法org.apache.flink.runtime.util.LeaderConnectionInfo
-
- 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
-
- 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.ActorSystemExecutorConfiguration
-
Create the executor Config
for the respective executor.
- 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
-
- getAllCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getAllCheckpoints() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getAllExceptions() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- getAllExecutionVertexIDs() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailoverRegion
-
Returns IDs of all vertices 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
-
- getAllExecutionVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailoverRegion
-
Returns all vertices in this region.
- getAllInputEdges() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getAllInputGates() - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
- getAllInputGates() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAllIntermediateResults() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllocatedSlotFuture() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- getAllocatedSlotInfos() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotReport
-
- getAllocatedSlots(JobID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of allocated slots for the given job id.
- getAllocatedSlots(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getAllocationId() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- 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.jobmaster.slotpool.SlotInfoWithUtilization
-
- getAllocationId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getAllocationId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- 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.slot.TaskSlotPayload
-
- 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
-
- getAllocationIdsPerJob(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getAllocationTimeout() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllPartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getAllPaths() - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Return a list of all valid paths for state handles.
- 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(int, Set<String>) - 类 中的方法org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- getAllVariables() - 类 中的方法org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- 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
-
- 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
.
- getArchivedExecutionGraphStore() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getArchivedExecutionGraphStore() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getArchivedJsons(Path) - 类 中的静态方法org.apache.flink.runtime.history.FsJobArchivist
-
- 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
-
- getAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAssignedResourceLocation() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedSlotRequest() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.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
-
- getAsyncOperationDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
Returns the description for this async operation header.
- getAsyncOperationDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getAsyncOperationDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getAsyncOperationDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getAsyncOperationDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getAttempt() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getAttemptId() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecution
-
- 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
-
- getAvailableBudget() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
- getAvailableFuture() - 接口 中的方法org.apache.flink.runtime.io.AvailabilityProvider
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Returns a future that is completed when there are free segments
in this pool.
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- getAvailableFuture() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- 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
-
- 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
-
- getAvailableSlotsInformation() - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- 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
-
- getBackoffTime() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- getBackoffTime() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- getBackoffTime() - 枚举 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.NoRestartBackoffTimeStrategy
-
- getBackoffTime() - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy
-
Returns the delay to do the restarting.
- getBackpressureLevel() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getBackpressureLevel() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getBackPressureRatio() - 类 中的方法org.apache.flink.runtime.messages.TaskBackPressureResponse
-
- getBackPressureRatio(int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the back pressure ratio of the given subtask index.
- getBackPressureRatios() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStats
-
- getBackPressureStatsTracker() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getBasePath() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- getBlobServer() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getBlobServer() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- 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.AbstractChannelWriterOutputView
-
Gets the number of blocks used by this 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
-
- getBlockingSubpartitionType() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- 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
-
- getBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
-
- getBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
-
- getBufferBuilder() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getBufferBuilder() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getBufferBuilder() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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.partition.consumer.RemoteInputChannel
-
- 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.io.disk.iomanager.AbstractChannelReaderInputView
-
Get the underlying channel.
- getChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get the underlying channel.
- getChannel() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- 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
-
- getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- 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
-
- getCheckpointFailureReason() - 异常错误 中的方法org.apache.flink.runtime.checkpoint.CheckpointException
-
- 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
-
- 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
-
- 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
-
- 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
-
- getCloseFuture() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getClusterHighAvailableStoragePath(Configuration) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Gets the cluster high available storage path from the provided configuration.
- getClusterInformation() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
-
- getClusterInformation() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the cluster information.
- getClusterPartitionReport() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
-
- getClusterRestEndpointLeaderElectionService() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the cluster's rest endpoint.
- getClusterRestEndpointLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getClusterRestEndpointLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getClusterRestEndpointLeaderElectionService() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getClusterRestEndpointLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.ClientHighAvailabilityServices
-
Get the leader retriever for the cluster's rest endpoint.
- getClusterRestEndpointLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getClusterRestEndpointLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getClusterRestEndpointLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneClientHAServices
-
- getClusterRestEndpointLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getClusterRestEndpointLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperClientHAServices
-
- getClusterRestEndpointLeaderRetriever() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getCoLocationConstraint() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getCoLocationConstraint() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getCoLocationGroup() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getCoLocationGroup() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
-
- getCommitId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- getCommittedBytes() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- 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
-
- getCompressionCodec() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- getCompressionDecorator(ExecutionConfig) - 类 中的静态方法org.apache.flink.runtime.state.AbstractStateBackend
-
- getCompressor() - 接口 中的方法org.apache.flink.runtime.io.compression.BlockCompressionFactory
-
- getCompressor() - 类 中的方法org.apache.flink.runtime.io.compression.Lz4BlockCompressionFactory
-
- getConfig() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getConfigDir() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getConfiguration() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getConfiguration() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getConfiguration() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- 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.shuffle.ShuffleEnvironmentContext
-
- getConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getConfiguration() - 接口 中的方法org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- getConfigurationMapLegacyTaskManagerHeapSizeToConfigOption(Configuration, ConfigOption<MemorySize>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- getConnectionId() - 类 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- getConnectionId() - 枚举 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
- getConnectionId() - 类 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo
-
- getConnectionId() - 接口 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.PartitionConnectionInfo
-
- getConnectionIndex() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getConnectionIndex() - 类 中的方法org.apache.flink.runtime.io.network.ConnectionID
-
- getConnectionManager() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getConnectionTimeout() - 类 中的方法org.apache.flink.runtime.rest.RestClientConfiguration
-
RestOptions.CONNECTION_TIMEOUT
.
- getConsumedPartitionShuffleDescriptor(ExecutionEdge, boolean) - 类 中的静态方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
- 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.InputGateID
-
- getConsumedResultId() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getConsumedResultPartitionsProducers(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
-
- getConsumedResultPartitionsProducers(ExecutionVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the producers of the result partitions consumed by an execution.
- getConsumedResults() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
-
- getConsumedResults() - 接口 中的方法org.apache.flink.runtime.topology.Vertex
-
- getConsumedSubpartitionIndex() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getConsumerExecutionState() - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
- getConsumerID() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGateID
-
- getConsumers() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getConsumers() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getConsumers() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
-
- getConsumers() - 接口 中的方法org.apache.flink.runtime.topology.Result
-
- 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.TaskExecutorProcessSpec
-
- getCpuCores() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the cpu cores needed.
- getCpuCores(Configuration) - 类 中的方法org.apache.flink.runtime.resourcemanager.ActiveResourceManager
-
- getCpuCores() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
-
- getCpuCoresWithFallback(Configuration, double) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- getCpuCoresWithFallbackConfigOption(Configuration, ConfigOption<Double>) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- 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
-
- 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.
- getCurrentAllocation(int) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getCurrentAssignedResource() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentAssignedResourceLocation() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- 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.
- getCurrentKey() - 类 中的方法org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- getCurrentKey() - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
-
- 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.
- getCurrentKeyGroupIndex() - 类 中的方法org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- 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.resourcemanager.registration.WorkerRegistration
-
- getDataPort() - 类 中的方法org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
-
- getDataPort() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getDataPort() - 类 中的方法org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getDataSetId() - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
-
- getDecompressor() - 接口 中的方法org.apache.flink.runtime.io.compression.BlockCompressionFactory
-
- getDecompressor() - 类 中的方法org.apache.flink.runtime.io.compression.Lz4BlockCompressionFactory
-
- getDefault() - 类 中的静态方法org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
- getDefaultAcl() - 类 中的方法org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getDefaultElement() - 类 中的方法org.apache.flink.runtime.util.EvictingBoundedList
-
- 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.
- getDefaultSlotResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
-
- getDefaultSlotResourceProfile() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- 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.groups.ReporterScopedSettings
-
- getDelimiter() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the global delimiter.
- getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getDelimiter() - 类 中的方法org.apache.flink.runtime.metrics.ReporterSetup
-
- getDeploymentOption() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexDeploymentOption
-
- getDescription() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- getDescription() - 接口 中的方法org.apache.flink.runtime.leaderelection.LeaderContender
-
- getDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
- getDescription() - 类 中的方法org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- 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.JobVertexWatermarksHeaders
-
- 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.SavepointStatusHeaders
-
- 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.job.UpperLimitExceptionParameter
-
- getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getDescription() - 类 中的方法org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- 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.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
-
- getDescription() - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- 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
-
- getDispatcherGateway() - 枚举 中的方法org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- 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
-
- 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
-
- getDynamicProperties() - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getDynamicPropertiesAsString(Configuration, Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
-
Get dynamic properties based on two Flink configurations.
- 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.BackPressureStats
-
- 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
-
- 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.
- getEntries() - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport
-
- 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(String, Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.BootstrapTools
-
Method to extract environment variables from the flinkConfiguration based on the given prefix String.
- getEnvironmentVariables() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the environment variables.
- getError() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns reason why the restarting cannot be conducted.
- 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
-
- getEventPublisher() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- 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.
- getExcludedVariables() - 类 中的方法org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
-
- getExcludedVariables() - 类 中的方法org.apache.flink.runtime.metrics.ReporterSetup
-
- 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.TaskBackPressureResponse
-
- getExecutionAttemptID() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- 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.DefaultExecutionGraphCache
-
- getExecutionGraph(JobID, RestfulGateway) - 接口 中的方法org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
- getExecutionGraph() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- getExecutionId() - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
Gets the ID of the task execution attempt.
- getExecutionId() - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
-
- getExecutionId() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getExecutionId() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
- getExecutionMode() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- getExecutionState() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- 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.
- getExecutionVertex(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- getExecutionVertexId() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexDeploymentOption
-
- getExecutionVertexId() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getExecutionVertexId() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexVersion
-
- getExecutionVertexId(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- getExecutionVertexId() - 类 中的方法org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- getExecutionVertexIdOrThrow(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- getExecutionVertexIds() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- getExecutor() - 类 中的方法org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getExecutor() - 接口 中的方法org.apache.flink.runtime.rpc.RpcService
-
Gets the executor, provided by this RPC service.
- 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
-
- getExternalSharedMemoryResource(String, LongFunctionWithException<T, Exception>, long) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Acquires a shared resource, identified by a type string.
- getFailedCheckpointStatistics() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getFailoverRegion(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Returns 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.
- getFailoverTopology() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getFailoverTopology() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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.NoOpResultSubpartitionView
-
- getFailureCause() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- 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
-
- getFailureHandlingResult(ExecutionVertexID, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler
-
Return result of failure handling.
- 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
-
- getFailureTimestamp() - 类 中的方法org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the timestamp when this checkpoint failed.
- getFailureTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- getFatalErrorHandler() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getFatalErrorHandler() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getFeatures() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- 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.
- getFilterStrategy() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer
-
- getFlinkConfig() - 类 中的方法org.apache.flink.runtime.security.SecurityConfiguration
-
- getFlinkConfiguration() - 类 中的方法org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the dynamic configuration.
- 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(OperatorID) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- getForShuffleOrBroadcast(ExecutionMode) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
-
- getFQDNHostname() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the fully-qualified domain name the TaskManager.
- getFrameworkHeapSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getFrameworkOffHeapMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- 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
-
- 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
-
- getGlobalAggregateManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
- getGlobalAggregateManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getGlobalAggregateManager() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getGlobalFailureHandlingResult(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler
-
Return result of failure handling on a global failure.
- getGlobalJobParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- getGlobalModVersion() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
Gets the global modification version of the execution graph when this execution was created.
- getGlobalModVersion() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the current global modification version of the ExecutionGraph.
- getGraph() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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
-
- getHardwareDescription() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getHardwareDescription() - 类 中的方法org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
-
- 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
-
- getHeaderLength() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedInputView
-
- getHeaderLength() - 类 中的方法org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- getHeartbeatServices() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getHeartbeatServices() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getHeartbeatTarget() - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target.
- getHeartbeatTarget() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- getHeartbeatTargetId() - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target id.
- getHeartbeatTargetId() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- getHighAvailabilityServices() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getHighAvailabilityServices() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getHistory() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint history.
- getHistory() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getHistoryServerArchivist() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getHistoryServerArchivist() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getHistoryServerURL(Configuration) - 枚举 中的静态方法org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
- getHost() - 类 中的方法org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getHostAddress() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getHostedPartitions() - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
-
- 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(RpcService) - 类 中的静态方法org.apache.flink.runtime.rpc.RpcUtils
-
Returns the hostname onto which the given
RpcService
has been bound.
- getHostname() - 类 中的方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager.
- getHostName(InetAddress) - 类 中的静态方法org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager based on the network address.
- 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
-
- 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.metrics.JobVertexWatermarksHeaders
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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.ExecutionVertex
-
- getId() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
-
- 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.jobgraph.topology.DefaultLogicalResult
-
- getId() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
-
- 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
- getId() - 接口 中的方法org.apache.flink.runtime.topology.Result
-
- getId() - 接口 中的方法org.apache.flink.runtime.topology.Vertex
-
- 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
-
- getInputChannelId() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInputChannels() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- 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
-
- getInputDependencyConstraint() - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Get InputDependencyConstraint
.
- getInputEdges(int) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getInputFormats() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- getInputFormats() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getInputGate(int) - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
- getInputGate(InputGateID) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getInputGate(int) - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getInputGates() - 类 中的方法org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getInputGroup() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- 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
-
- getInputsLocationsRetriever() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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.heartbeat.NoOpHeartbeatManager
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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.resourcemanager.registration.TaskExecutorConnection
-
- getInstanceId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getInstanceId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- getInstanceId() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
- getIntermediateDataSetID() - 类 中的方法org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getIntermediateDataSetId() - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
-
- 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
-
- 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
-
- getIntervalSettings() - 类 中的方法org.apache.flink.runtime.metrics.ReporterSetup
-
- 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.
- getIOExecutor() - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
-
- getIoExecutor() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getIOManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
- 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.scheduler.SchedulerBase
-
- getJobGraphStore() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the submitted job graph store for the job manager.
- getJobGraphStore() - 类 中的方法org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getJobGraphStore() - 类 中的方法org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobGraphWriter() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getJobGraphWriter() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServicesWithJobGraphStore
-
- 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.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.jobgraph.JobGraph
-
Returns the ID of the job.
- getJobId() - 类 中的方法org.apache.flink.runtime.jobmaster.AllocatedSlotReport
-
- getJobID() - 接口 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Get the job id of the executed job.
- getJobID() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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.resourcemanager.registration.JobManagerRegistration
-
- getJobId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getJobId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- 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.slot.TaskSlotPayload
-
- 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.SingleJobJobGraphStore
-
- getJobIds() - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphStore
-
Get all job ids of submitted job graphs to the submitted job graph store.
- getJobIds() - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- getJobIds() - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- 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
-
- 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
-
- 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.
- getJobManagerMetricGroup() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getJobManagerMetricGroupFactory() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getJobManagerMetricStore() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- 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
-
- getJobMasterGateway() - 接口 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getJobMasterGateway() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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
-
- 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.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
-
- getJobTimeout() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getJobVertex(JobVertexID) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- 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
-
- 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.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getJobVertexId() - 类 中的方法org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
- 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
-
- getJvmDirectMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getJvmHeapMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getJvmMetaspaceSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getJvmOverheadSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- 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.io.network.partition.PartitionTrackerEntry
-
- 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.CopyOnWriteStateMap.StateMapEntry
-
- 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.DualKeyLinkedMap
-
- getKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- 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
-
- 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() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- getKeyGroupOffset(int) - 类 中的方法org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns the offset for the given key-group.
- 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.heap.InternalKeyContextImpl
-
- 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.HeapPriorityQueueStateSnapshot
-
- getKeyGroupWriter() - 接口 中的方法org.apache.flink.runtime.state.StateSnapshot
-
- getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- getKeys(String, N) - 类 中的方法org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- getKeys(N) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
- 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.StateTable
-
- 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.KeyedStateBackend
-
- 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.
- getKvStateClientProxy() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- getKvStateID(int) - 类 中的方法org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered KvStateID for the key group index or
null
if none is registered yet.
- 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
-
- getKvStateRegistry() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- getKvStateServer() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- 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.
- getKvStateService() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- 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.heartbeat.HeartbeatMonitor
-
Gets the last heartbeat.
- getLastHeartbeat() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- 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
-
- getLastHeartbeatFrom(ResourceID) - 类 中的方法org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
-
- getLastOutputCollector() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
- getLastState() - 类 中的方法org.apache.flink.runtime.checkpoint.DefaultLastStateConnectionStateListener
-
- getLastState() - 接口 中的方法org.apache.flink.runtime.checkpoint.LastStateConnectionStateListener
-
Return the last state the listener was notified about.
- 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(boolean) - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- 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.
- getLeaderAddressFuture() - 枚举 中的方法org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- getLeaderConnectionInfoFuture() - 类 中的方法org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
-
- getLeaderFuture() - 类 中的方法org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current JobManagerGateway future.
- 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.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- 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.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
-
- getLocalRecoveryConfig() - 类 中的方法org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- 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.
- getLogicalPipelinedRegions() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
-
- 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
-
- getLogicalSlotFuture() - 类 中的方法org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- 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.
- getMainThreadExecutor() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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
-
- getManagedMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the managed memory needed.
- getManagedMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getManagedMemorySize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
-
- getManagedMemorySize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- 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.PendingCheckpoint
-
- 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
-
- getMaxCompressedSize(int) - 接口 中的方法org.apache.flink.runtime.io.compression.BlockCompressor
-
Get the max compressed size for a given original size.
- getMaxCompressedSize(int) - 类 中的方法org.apache.flink.runtime.io.compression.Lz4BlockCompressor
-
- 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
-
- getMaxNumberRestartAttempts() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- 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
-
- getMemoryManager() - 接口 中的方法org.apache.flink.runtime.execution.Environment
-
- getMemoryManager() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
- getMemoryManager() - 接口 中的方法org.apache.flink.runtime.operators.TaskContext
-
- getMemoryManager() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- 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.
- 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
-
- getMemorySize() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Returns the total size of memory handled by this memory manager.
- 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.
- 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.io.network.partition.PartitionTrackerEntry
-
- getMetaInfo() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
- getMetaInfo() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- 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, char) - 类 中的方法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
-
- getMetricQueryServiceAddress() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getMetricQueryServiceAddress() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- getMetricQueryServiceGatewayRpcAddress() - 接口 中的方法org.apache.flink.runtime.metrics.MetricRegistry
-
- getMetricQueryServiceGatewayRpcAddress() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getMetricQueryServiceRpcService() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- 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.metrics.ReporterSetup
-
- 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.CopyOnWriteStateMap.StateMapEntry
-
- getNamespace() - 接口 中的方法org.apache.flink.runtime.state.StateEntry
-
Returns the namespace of this entry.
- getNamespace() - 类 中的方法org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
-
- getNamespaceMap() - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- getNamespaceSerializer() - 类 中的方法org.apache.flink.runtime.query.KvStateInfo
-
- 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
-
- 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.NettyShuffleEnvironment
-
- getNetworkInterfaceNames() - 类 中的方法org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getNetworkMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the network memory needed.
- getNetworkMemorySize() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getNetworkMemorySize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getNetworkMemSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getNetworkMemSize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
-
- 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
-
- getNext() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getNext() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNext() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- getNext() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- getNextBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getNextBuffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- getNextBuffer() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Returns the next
Buffer
instance of this queue iterator.
- getNextInputSplit() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- getNextInputSplit(String) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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
-
- getNextReceivedBuffer() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- 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
-
- 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
-
- getNumberAssignedPendingTaskManagerSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- 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.SlotManagerImpl
-
- getNumberFreeSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberFreeSlotsOf(InstanceID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberFreeSlotsOf(InstanceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberInProgressCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- 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.
- 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
-
- 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
-
- 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.
- 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.
- getNumberOfInputChannels() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- 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
-
- 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.heap.InternalKeyContextImpl
-
- getNumberOfKeyGroups() - 类 中的方法org.apache.flink.runtime.state.KeyGroupRange
-
- getNumberOfKeyGroups() - 接口 中的方法org.apache.flink.runtime.state.KeyGroupsList
-
Returns the number of key group ids in the list.
- getNumberOfNonAcknowledgedTasks() - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- 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.io.network.partition.TaskExecutorPartitionInfo
-
- 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.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.
- getNumberOfRestarts() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the number of restarts, including full restarts and fine grained restarts.
- getNumberOfRestarts() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler
-
- getNumberOfRestarts() - 类 中的方法org.apache.flink.runtime.scheduler.DefaultScheduler
-
- getNumberOfRestarts() - 类 中的方法org.apache.flink.runtime.scheduler.LegacyScheduler
-
- getNumberOfRestarts() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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.io.network.netty.NettyConfig
-
- getNumberOfSlots() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- 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
-
- getNumberOfSubpartitions() - 类 中的方法org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getNumberOfSubpartitions() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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
-
- getNumberOfVariablesWithReferences() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- getNumberOfVertices() - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the number of all vertices.
- getNumberPendingSlotRequests() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberPendingSlotRequests() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberPendingTaskManagerSlots() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberPendingTaskManagerSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberRegisteredSlots() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberRegisteredSlots() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberRegisteredSlotsOf(InstanceID) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlotsOf(InstanceID) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- 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.io.network.metrics.InputChannelMetrics
-
- getNumBuffersInRemoteCounter() - 类 中的方法org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBuffersOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytes() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output bytes.
- getNumBytesIn() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInLocalCounter() - 类 中的方法org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBytesInRemoteCounter() - 类 中的方法org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBytesOut() - 类 中的方法org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesOutCounter() - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumCompressedBytes() - 类 中的方法org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output compressed bytes, return num bytes if there is no compression.
- 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
-
- getNumIoThreads() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- 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
-
- 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
-
- 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
-
- getNumTargetKeyGroups() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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
-
- getNumTotalPartitions() - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
-
- 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 an 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
-
- getOperatorsMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory the operators needed.
- getOperatorState(ListStateDescriptor<S>) - 类 中的方法org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- 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
-
- getOutputFormats() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- getOutputFormats() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getOutputGroup() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- 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.
- getOwnerName() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getOwningJob(AllocationID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- getOwningJob(AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getOwningTaskName() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPageSize() - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Gets the size of the pages handled by the memory manager.
- getPageSize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getPageSize(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the page size and validates the value.
- 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
-
- getParallelism() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- 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
-
- getParameters(OperatorID) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- 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
- getParentGroup() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getParentMetricGroup() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- 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.PartitionException
-
- getPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getPartitionId() - 类 中的方法org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getPartitionId() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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.
- getPartitions() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getPartitionsOccupyingLocalResources() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Report unreleased partitions.
- getPartitionsOccupyingLocalResources() - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Report partitions which still occupy some resources locally.
- getPartitionStateChecker() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getPartitionStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- getPartitionTracker() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getPartitionType() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionType() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the type of this result partition.
- getPartitionType() - 类 中的方法org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- 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.ZooKeeperJobGraphStore
-
Returns the JobID as a String (with leading slash).
- getPathParameter(Class<PP>) - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
-
- 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.JobCancellationMessageParameters
-
- getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameters
-
- getPathParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- getPaths() - 接口 中的方法org.apache.flink.runtime.io.disk.FileChannelManager
-
Gets all the files corresponding to the config temp dirs.
- getPaths() - 类 中的方法org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- 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.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
-
- 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.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
-
- getPhysicalSlotNumber() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotInfoWithUtilization
-
- getPhysicalSlotResourceProfile() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the physical slot to host this task slot.
- getPhysicalSlotResourceProfile() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getPhysicalSlotResourceProfile(ExecutionVertex) - 类 中的静态方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirementsMapper
-
Get resource profile of the physical slot to allocate a logical slot in for the given vertex.
- getPipelineBreakingExchange(ExecutionMode) - 枚举 中的静态方法org.apache.flink.runtime.io.network.DataExchangeMode
-
- getPoolSize(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ClusterEntrypointUtils
-
Gets and verify the io-executor pool size based on configuration.
- 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.
- 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.
- getPreferredLocationBasedOnState() - 类 中的方法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.
- 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.
- getPreferredLocations() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- 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.
- getPreviousAllocationId() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- 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
-
- getPreviousSerializerSnapshot() - 类 中的方法org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the previous serializer snapshot.
- getPreviousStateSerializer() - 类 中的方法org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getPreviousStateSerializerSnapshot() - 类 中的方法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
-
- getProducedResults() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
-
- getProducedResults() - 接口 中的方法org.apache.flink.runtime.topology.Vertex
-
- getProducer() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getProducer() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getProducer() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getProducer() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
-
- getProducer() - 接口 中的方法org.apache.flink.runtime.topology.Result
-
- getProducerExecutionId() - 类 中的方法org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getProducerExecutionState() - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
- getProducerId() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getProducerLocation() - 类 中的方法org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- 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
-
- getQueryParameter(Class<QP>) - 类 中的方法org.apache.flink.runtime.rest.handler.HandlerRequest
-
- 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.JobExceptionsMessageParameters
-
- 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.JobCancellationMessageParameters
-
- getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameters
-
- getQueryParameters() - 类 中的方法org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- 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
-
- 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
-
- 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
-
- getRecordWriter(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
-
- getRecordWriter(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
-
- getRecordWriter(int) - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriterDelegate
-
Returns the internal actual record writer instance based on the output index.
- getRecordWriter(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
-
- 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
-
- 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.
- 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.
- getRemainingResources() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- getReporter() - 类 中的方法org.apache.flink.runtime.metrics.ReporterSetup
-
- getReporterIndex() - 类 中的方法org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
-
- 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.metrics.JobVertexWatermarksHeaders
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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
-
- getRequestId() - 类 中的方法org.apache.flink.runtime.messages.TaskBackPressureResponse
-
- getRequestId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStats
-
- getRequestId() - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
- getRequestSegmentsTimeout() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- getRequiredClasspathURLs() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
-
- getRequiredJarFileBlobKeys() - 类 中的方法org.apache.flink.runtime.executiongraph.JobInformation
-
- getReservedResources() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
- getReservedResources() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
-
- getReservedResources() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Gets the total reserved resources of the slot and its descendants.
- 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.
- getResourceHandle() - 类 中的方法org.apache.flink.runtime.memory.OpaqueMemoryResource
-
Gets the handle to the resource.
- 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.resourcemanager.TaskExecutorRegistration
-
- 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.taskexecutor.TaskManagerServicesConfiguration
-
- 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.
- getResourceManagerGatewayRetriever() - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherServices
-
- getResourceManagerGatewayRetriever() - 类 中的方法org.apache.flink.runtime.dispatcher.PartialDispatcherServices
-
- 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.executiongraph.AccessExecutionJobVertex
-
Returns the resource profile for this job vertex.
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getResourceProfile() - 接口 中的方法org.apache.flink.runtime.jobmaster.SlotInfo
-
Returns the resource profile of the slot.
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotInfoWithUtilization
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
-
- getResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- getResourceProfile() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
Get resource profile of this slot.
- 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.
- getResourceSpec() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- 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.metrics.JobVertexWatermarksHeaders
-
- 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.JobCancellationHeaders
-
- 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.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.metrics.JobVertexWatermarksHeaders
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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
-
- getRestartDelayMS() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns the delay before the restarting.
- getRestartStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRestartStrategy() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- 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
-
Get the result future of this runner.
- getResultFuture() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- getResultId() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getResultId() - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets id of the intermediate result.
- getResultId() - 类 中的方法org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getResultOptimizerProperties() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
-
- getResultPartition(IntermediateResultPartitionID) - 类 中的方法org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
-
- getResultPartition(IntermediateResultPartitionID) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getResultPartitionAvailabilityChecker() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getResultPartitionAvailabilityChecker() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- getResultPartitionConsumableNotifier() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getResultPartitionDeploymentDescriptor(IntermediateResultPartitionID) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- getResultPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.PartitionTrackerEntry
-
- getResultPartitionId() - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
-
- getResultPartitionID() - 类 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- getResultPartitionID() - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
- getResultPartitionID() - 类 中的方法org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- getResultPartitionManager() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getResultPartitionOrThrow(IntermediateResultPartitionID) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getResultType() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getResultType() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getResultType() - 类 中的方法org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getResultType() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
-
- getResultType() - 接口 中的方法org.apache.flink.runtime.topology.Result
-
- getRetryingRegistrationConfiguration() - 类 中的方法org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getRetryingRegistrationConfiguration() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- 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.
- getRootException() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- getRootTimestamp() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- 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
-
- 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
-
- 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
-
- getSchedulingTopology() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSchedulingTopology() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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
-
- 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
-
- getSerializer(int) - 类 中的静态方法org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- 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
-
- getSharedMemoryResourceForManagedMemory(String, LongFunctionWithException<T, Exception>) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Acquires a shared memory resource, that uses all the memory of this memory manager.
- getSharedMemoryResourceForManagedMemory(String, LongFunctionWithException<T, Exception>, double) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Acquires a shared memory resource, identified by a type string.
- 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", ...
- getShuffleDescriptor() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getShuffleDescriptor() - 类 中的方法org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getShuffleDescriptors() - 类 中的方法org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getShuffleEnvironment() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getShutDownFuture() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- getShutDownFuture() - 类 中的方法org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
-
- getShutDownFuture() - 接口 中的方法org.apache.flink.runtime.dispatcher.runner.DispatcherRunner
-
Return shut down future of this runner.
- getShutDownFuture() - 枚举 中的方法org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- 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.io.network.partition.consumer.BufferOrEvent
-
- getSize() - 类 中的方法org.apache.flink.runtime.memory.OpaqueMemoryResource
-
Gets the size, in bytes.
- 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.
- getSlot() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- getSlot(Configuration) - 类 中的静态方法org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the number of slots and validates the value.
- getSlotId() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- getSlotId() - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
- 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
-
- getSlotInfo() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- getSlotManager() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- getSlotManagerConfiguration() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getSlotNumber() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotID
-
- getSlotProviderStrategy() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSlotReport() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
-
- 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.SlotPoolImpl.PendingRequest
-
- 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.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
-
- getSlotSharingGroupId() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- 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.
- 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.BackPressureStats
-
- 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
-
- getStartTimeCompatible() - 类 中的方法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.executiongraph.AccessExecution
-
- 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.query.KvStateEntry
-
- getState() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- getState() - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Gets the state of the execution vertex.
- getState() - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
- getState(ValueStateDescriptor<T>) - 类 中的方法org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getState() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
-
- getState() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
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
-
- getStateBackendName() - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the state backend name for this ExecutionGraph.
- getStateBackendName() - 类 中的方法org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getStateBackendName() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
- getStateIncrementalVisitor(int) - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- getStateIncrementalVisitor(int) - 接口 中的方法org.apache.flink.runtime.state.internal.InternalKvState
-
Get global visitor of state entries.
- getStateMapSnapshotForKeyGroup(int) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
-
- 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.CopyOnWriteStateMap
-
- 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 server 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
-
- getStateTimestamp(ExecutionState) - 接口 中的方法org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- 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
-
- 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
-
- getStopTerminationFutureOrCompletedExceptionally(Throwable) - 类 中的方法org.apache.flink.runtime.resourcemanager.ActiveResourceManager
-
- 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
-
- getStoredJobsOverview() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getStoredJobsOverview() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- 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.NoOpFailoverStrategy
-
- getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
-
- getStrategyName() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
- 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.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
-
- 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
-
- getSubtaskIndex() - 类 中的方法org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
- getSubtaskMetricStore(String, String, int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getSubtaskMetricStore(int) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
-
- getSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getSubtasks() - 类 中的方法org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- 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
-
- getSystemPageSize() - 类 中的静态方法org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrConservativeMultiple() - 类 中的静态方法org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrDefault() - 类 中的静态方法org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- 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
-
- getTargetDirectory() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- 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.JobVertexWatermarksHeaders
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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.
- getTask(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- 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.taskexecutor.TaskManagerServices
-
- getTaskEventDispatcher() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskExecutionId() - 类 中的方法org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getTaskExecutorAddress() - 类 中的方法org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
-
- getTaskExecutorGateway() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getTaskExecutorProcessSpec() - 类 中的方法org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- getTaskExecutorResourceId() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getTaskExecutorResourceSpec() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTaskExecutorUtilization() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- getTaskFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskHeapMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the task heap memory needed.
- getTaskHeapSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getTaskHeapSize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
-
- 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
-
- getTaskKvStateRegistry() - 类 中的方法org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskLocalSnapshot() - 类 中的方法org.apache.flink.runtime.state.SnapshotResult
-
- getTaskManagerActions() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getTaskManagerBindAddress() - 类 中的方法org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getTaskManagerConnection() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getTaskManagerConnection() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlot
-
- getTaskManagerFormat() - 类 中的方法org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- 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.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- 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.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.jobmaster.slotpool.SlotInfoWithUtilization
-
- getTaskManagerLocation(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
-
- getTaskManagerLocation(ExecutionVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the task manager location future for an execution.
- 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
-
- 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<?>, String) - 类 中的静态方法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
-
- getTaskMemoryManager(AllocationID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the memory manager of the slot allocated for the task.
- getTaskMemoryManager(AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getTaskMetricStore(String, String) - 类 中的方法org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- 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.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
-
- getTaskOffHeapMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the task off-heap memory needed.
- getTaskOffHeapSize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getTaskOffHeapSize() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
-
- getTaskOwnedStateDirectory() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getTaskResourceProfile() - 类 中的方法org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the task slot.
- getTaskResourceProfile() - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- 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.
- getTasks(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- getTaskSlotTable() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailoverStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartAllStrategy
-
Returns all vertices on any task failure.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- 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
-
- 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
-
- getTempDirs() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- 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
-
- 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.scheduler.SchedulerBase
-
- getTerminationFuture() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- getTerminationFuture() - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
-
- getTerminationFuture() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- getTerminationFuture() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
- getThreadPriority() - 类 中的方法org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
-
- getThrowableType(Throwable) - 类 中的静态方法org.apache.flink.runtime.throwable.ThrowableClassifier
-
- 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
-
- 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
-
- 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
-
- getTolerableCheckpointFailureNumber() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getTotalBudget() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
-
- getTotalFields() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getTotalFlinkMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getTotalMemory() - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the total memory needed.
- getTotalNumberCheckpoints() - 类 中的方法org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getTotalNumberOfBuffers() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Gets the total numbers of buffers (data buffers plus events).
- 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
-
- getTotalNumberOfPartitions() - 类 中的方法org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getTotalNumberOfPartitions() - 类 中的方法org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getTotalNumberOfVertices() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getTotalProcessMemorySize() - 类 中的方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
-
- getTotalResourceProfile() - 类 中的方法org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
-
- getTotalResourceProfile() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- 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.
- getUnavailableToResetAvailable() - 类 中的方法org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
- getUnavailableToResetUnavailable() - 类 中的方法org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Creates a new uncompleted future as the current state and returns the
previous uncompleted one.
- 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
-
- getUniqueInputFormat() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getUniqueOutputFormat() - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getUnmodifiedExecutionVertices(Set<ExecutionVertexVersion>) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- getUnreleasedPartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- 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.JobVertexWatermarksHeaders
-
- 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.savepoints.stop.StopWithSavepointTriggerHeaders
-
- 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.JobCancellationHeaders
-
- 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.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
-
- 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
-
- getUserClassPaths() - 类 中的方法org.apache.flink.runtime.entrypoint.component.AbstractUserClassPathJobGraphRetriever
-
- 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.RestartTimeGauge
-
- getValue() - 类 中的方法org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
-
- getValue() - 类 中的方法org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- getValue() - 类 中的方法org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
-
- getValue() - 类 中的方法org.apache.flink.runtime.io.network.metrics.OutputBufferPoolUsageGauge
-
- getValue() - 类 中的方法org.apache.flink.runtime.io.network.metrics.OutputBuffersGauge
-
- 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
-
- 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.scheduler.ExecutionVertexVersion
-
- 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
-
- getVertex(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
-
- getVertex(ExecutionVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getVertexId() - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getVertexIDs() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.LogicalPipelinedRegion
-
- getVertexOrThrow(ExecutionVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- 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.
- getVertices() - 类 中的方法org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
-
- getVertices() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getVertices() - 类 中的方法org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
-
- getVertices() - 接口 中的方法org.apache.flink.runtime.topology.Topology
-
Returns an iterable over all vertices, topologically sorted.
- 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
-
- getVerticesToRestart() - 类 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns the tasks to restart.
- getVerticesToTrigger() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getWaitForSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- getWebMonitorAddress(Configuration, HighAvailabilityServicesUtils.AddressResolution) - 类 中的静态方法org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Get address of web monitor from configuration.
- getWebMonitorLeaderElectionService() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebMonitorLeaderRetriever() - 接口 中的方法org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebUiDir() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getWorker() - 类 中的方法org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getWorkerIndex() - 类 中的方法org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- getWrappedException() - 异常错误 中的方法org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
-
- getWriteBufferSize() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the write buffer size for created checkpoint stream.
- 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
-
- 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.runner.DefaultDispatcherRunner
-
- grantLeadership(UUID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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
-
- 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
-
- id - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
The ID of the underlying channel.
- ID(File, int, Random) - 类 的构造器org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
- IllegalExecutionStateException - org.apache.flink.runtime.executiongraph中的异常错误
-
- 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.
- increment() - 类 中的方法org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Increments the reference count and returns whether it was successful.
- IncrementalKeyedStateHandle - org.apache.flink.runtime.state中的接口
-
- IncrementalLocalKeyedStateHandle - org.apache.flink.runtime.state中的类
-
- 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
-
- incrementRestarts() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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
-
- 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
-
- 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.messages.webmonitor中的接口
-
Abstract base interface of all info messages exchanged between the
JobManager an for example the runtime monitor.
- initBroadcastInputReaders() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
- initBroadcastInputsSerializers(int) - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
Creates all the serializers and iterators for the broadcast inputs.
- initFailureCause(Throwable) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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
-
- initializeBaseLocations() - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes the necessary prerequisites for storage locations of checkpoints/savepoints.
- initializeBaseLocations() - 类 中的方法org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- initializeBaseLocations() - 类 中的方法org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- initializeBroadcastVariable(Iterable<T>) - 类 中的方法org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- 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.CheckpointStorageCoordinatorView
-
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.CheckpointStorageCoordinatorView
-
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.InputOutputFormatVertex
-
- 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.
- initializeServices(Configuration) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- initializeWebSubmissionHandlers(CompletableFuture<String>) - 类 中的方法org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
-
- initializeWebSubmissionHandlers(CompletableFuture<String>) - 类 中的方法org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- initialPartitionBuffersCount - 类 中的变量org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- initInputReaders() - 类 中的方法org.apache.flink.runtime.operators.BatchTask
-
- 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中的类
-
- 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中的接口
-
- 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.io.network.partition.consumer.InputGate.InputWithData
-
- input - 类 中的变量org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- input - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- input - 类 中的变量org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- InputBuffersGauge - org.apache.flink.runtime.io.network.metrics中的类
-
Gauge metric measuring the number of queued input buffers for
SingleInputGate
s.
- InputBuffersGauge(SingleInputGate[]) - 类 的构造器org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
-
- InputChannel - org.apache.flink.runtime.io.network.partition.consumer中的类
-
- 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.
- 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
-
- InputChannelMetrics - org.apache.flink.runtime.io.network.metrics中的类
-
- InputChannelMetrics(MetricGroup...) - 类 的构造器org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- inputComparators - 类 中的变量org.apache.flink.runtime.operators.BatchTask
-
The comparators for the central driver.
- InputDependencyConstraintChecker - org.apache.flink.runtime.scheduler.strategy中的类
-
A wrapper class for InputDependencyConstraint
checker.
- InputDependencyConstraintChecker() - 类 的构造器org.apache.flink.runtime.scheduler.strategy.InputDependencyConstraintChecker
-
- 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.
- InputGate() - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- InputGate.InputWithData<INPUT,DATA> - org.apache.flink.runtime.io.network.partition.consumer中的类
-
Simple pojo for INPUT, DATA and moreAvailable.
- InputGateDeploymentDescriptor - org.apache.flink.runtime.deployment中的类
-
Deployment descriptor for a single input gate instance.
- InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, ShuffleDescriptor[]) - 类 的构造器org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- InputGateID - org.apache.flink.runtime.io.network.partition.consumer中的类
-
- InputGateID(IntermediateDataSetID, ExecutionAttemptID) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.InputGateID
-
- InputGateMetrics - org.apache.flink.runtime.io.network.metrics中的类
-
Collects metrics of an input gate.
- inputGates - 类 中的变量org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- InputGateWithMetrics - org.apache.flink.runtime.taskmanager中的类
-
This class wraps
InputGate
provided by shuffle service and it is mainly
used for increasing general input metrics from
TaskIOMetricGroup
.
- InputGateWithMetrics(InputGate, Counter) - 类 的构造器org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- inputIterators - 类 中的变量org.apache.flink.runtime.operators.BatchTask
-
The inputs reader, wrapped in an iterator.
- InputOutputFormatContainer - org.apache.flink.runtime.jobgraph中的类
-
A container for InputFormats
and OutputFormats
, along with
their Configuration
.
- InputOutputFormatContainer(ClassLoader) - 类 的构造器org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- InputOutputFormatContainer(TaskConfig, ClassLoader) - 类 的构造器org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- InputOutputFormatContainer.FormatUserCodeTable - org.apache.flink.runtime.jobgraph中的类
-
Container for multiple wrappers containing InputFormat
and OutputFormat
code.
- InputOutputFormatVertex - org.apache.flink.runtime.jobgraph中的类
-
A task vertex that runs an initialization and a finalization on the master.
- InputOutputFormatVertex(String) - 类 的构造器org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- InputOutputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - 类 的构造器org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- 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.
- InputsLocationsRetriever - org.apache.flink.runtime.scheduler中的接口
-
Component to retrieve the inputs locations of a
Execution
.
- 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.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.rest.messages.DashboardConfigurationHeaders
-
- INSTANCE - 类 中的静态变量org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
-
- 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
-
- 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
-
- instantiateJobManagerMetricGroup(MetricRegistry, String) - 类 中的静态方法org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateProcessMetricGroup(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, String, ResourceID, 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.
- InsufficientBufferException - org.apache.flink.runtime.io.compression中的异常错误
-
An InsufficientBufferException
is thrown when there is no enough buffer to
serialize or deserialize a buffer to another buffer.
- InsufficientBufferException() - 异常错误 的构造器org.apache.flink.runtime.io.compression.InsufficientBufferException
-
- InsufficientBufferException(String) - 异常错误 的构造器org.apache.flink.runtime.io.compression.InsufficientBufferException
-
- InsufficientBufferException(String, Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.compression.InsufficientBufferException
-
- InsufficientBufferException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.io.compression.InsufficientBufferException
-
- 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.
- internalCallOnStart() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
-
Internal method which is called by the RpcService implementation to start the RpcEndpoint.
- internalCallOnStop() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
-
Internal method which is called by the RpcService implementation to stop the RpcEndpoint.
- 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
-
- InternalFailuresListener - org.apache.flink.runtime.scheduler中的接口
-
This interface enables subscribing to failures that are detected from the JobMaster side
(e.g., from within the
ExecutionGraph
).
- InternalFoldingState<K,N,T,ACC> - org.apache.flink.runtime.state.internal中的接口
-
- 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.
- InternalKeyContextImpl<K> - org.apache.flink.runtime.state.heap中的类
-
- InternalKeyContextImpl(KeyGroupRange, int) - 类 的构造器org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- 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_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_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
-
- 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) - 类 的构造器org.apache.flink.runtime.executiongraph.IOMetrics
-
- IOMetrics(long, long, long, long) - 类 的构造器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
-
- IS_BACKPRESSURED - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
-
- isAcknowledgedBy(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isActive(JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- 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.
- isAllocated(int, JobID, AllocationID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- isApproximatelyAvailable() - 接口 中的方法org.apache.flink.runtime.io.AvailabilityProvider
-
- 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
-
- isAvailable(IntermediateResultPartitionID) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraphResultPartitionAvailabilityChecker
-
- isAvailable(IntermediateResultPartitionID) - 接口 中的方法org.apache.flink.runtime.executiongraph.failover.flip1.ResultPartitionAvailabilityChecker
-
Returns whether the given partition is available.
- isAvailable() - 接口 中的方法org.apache.flink.runtime.io.AvailabilityProvider
-
In order to best-effort avoid volatile access in
CompletableFuture.isDone()
, we check the condition
of
future == AVAILABLE
firstly for getting probable performance benefits while hot looping.
- isAvailable() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
-
- isAvailable() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
-
- isAvailable() - 类 中的方法org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
-
- isAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Checks whether this reader is available or not.
- isAvailable() - 类 中的方法org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- isAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isBackPressured() - 接口 中的方法org.apache.flink.runtime.taskexecutor.BackPressureSampleableTask
-
- isBackPressured() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
- isBasicType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isBatchRequest() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- isBlocking() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isBlockingShuffleCompressionEnabled() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- 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.heartbeat.HeartbeatMonitorImpl
-
- 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.io.network.NettyShuffleEnvironment
-
- 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
-
- isClosed() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- isCompacted() - 类 中的方法org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- isCompleted() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has completed successfully.
- isCompressed() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
-
- isCompressed() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isCompressed() - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isConnected() - 类 中的方法org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- isConsumable() - 类 中的方法org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- isConverged(int, LongValue) - 类 中的方法org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- isDataAvailable() - 类 中的方法org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns true if there is new data available for reading.
- 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.StateMap
-
- isEmpty() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- 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.
- 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
-
- 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
-
- isFinished() - 接口 中的方法org.apache.flink.runtime.io.PullingAsyncDataInput
-
- isFinished() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- isForcePartitionReleaseOnConsumption() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- 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.
- 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
-
- isLegacyScheduling() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isLegacyScheduling() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- isLocalCommunicationOnly() - 类 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- isLocalRecoveryEnabled() - 类 中的方法org.apache.flink.runtime.state.LocalRecoveryConfig
-
- isLocalTo(ResourceID) - 类 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- isManagedMemorySizeExplicitlyConfigured(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- 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.resourcemanager.slotmanager.TaskManagerSlot
-
Check whether required resource profile can be matched by this slot.
- isMatchingRequirement(ResourceProfile) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
Returns true if the required
ResourceProfile
can be fulfilled
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
-
- isModified(ExecutionVertexVersion) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- isMoreAvailable() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
-
- isNetworkDetailedMetrics() - 类 中的方法org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- isNetworkMemoryExplicitlyConfigured(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- isNetworkStrategy() - 枚举 中的方法org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- isNullOrEmpty(ChainedStateHandle<?>) - 类 中的静态方法org.apache.flink.runtime.state.ChainedStateHandle
-
- isNumBytesInComplete() - 类 中的方法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
-
- isObjectReuse() - 类 中的方法org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
-
- isOutputVertex() - 类 中的方法org.apache.flink.runtime.jobgraph.JobVertex
-
- isOwner(T) - 类 中的方法org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Returns true iff the given state map is the owner of this snapshot object.
- isPartitionTracked(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
-
- isPartitionTracked(ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether the given partition is being tracked.
- isPeriodicCheckpointingConfigured() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Returns whether periodic checkpointing has been configured.
- isPersistent() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isPipelined() - 枚举 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isPreferCheckpointForRecovery() - 类 中的方法org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- isPreFlight() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
- isProducerReadyOrAbortConsumption(PartitionProducerStateProvider.ResponseHandle) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
-
- 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
-
- isRegisteredAsAvailable() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- 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.NoOpResultSubpartitionView
-
- 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
-
- isReleased() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
-
- isReleasing() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- 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.
- 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.
- isRunning() - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns whether the RPC endpoint is started and not stopped or being stopped.
- isRunning() - 接口 中的方法org.apache.flink.runtime.taskexecutor.BackPressureSampleableTask
-
- isRunning() - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
- 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.checkpoint.CheckpointType
-
- 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.memory.MemoryManager
-
Checks whether the MemoryManager has been shut down.
- isShutdown() - 类 中的方法org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns whether this registry has been shutdown.
- isShutdown() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- isSlotFree(int) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the task slot with the given index is free.
- isSlotFree(int) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- 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
-
- isSSLEnabled(Configuration) - 枚举 中的静态方法org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
- isStableVersion() - 枚举 中的方法org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns whether this version is considered stable.
- isStarted() - 类 中的方法org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Checks whether the service has been started.
- 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.jobmaster.JobResult
-
Returns true
if the job finished successfully.
- isSynchronous() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a synchronous savepoint/checkpoint.
- isSynchronous() - 枚举 中的方法org.apache.flink.runtime.checkpoint.CheckpointType
-
- isTaskExecutorProcessResourceExplicitlyConfigured(Configuration) - 类 中的静态方法org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
-
- isTerminal() - 枚举 中的方法org.apache.flink.runtime.execution.ExecutionState
-
- isTrackingPartitionsFor(K) - 类 中的方法org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
-
- isTrackingPartitionsFor(K) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether any partition is being tracked for the given key.
- isTruncated() - 类 中的方法org.apache.flink.runtime.rest.messages.JobExceptionsInfo
-
- isTtlStateSerializer(TypeSerializer<?>) - 类 中的静态方法org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- isTupleType() - 类 中的方法org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isUnknown() - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns whether the partition is known and registered with the
ShuffleMaster
implementation.
- isUnknown() - 类 中的方法org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- 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.
- isValidTimeout(AllocationID, UUID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- isWaitResultConsumedBeforeRelease() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- isWebSubmitEnabled() - 类 中的方法org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- isWebSubmitEnabled() - 类 中的方法org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
-
- 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
-
- 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.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- 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.CopyOnWriteStateMap
-
- iterator() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- iterator() - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- iterator() - 类 中的方法org.apache.flink.runtime.state.heap.StateTable
-
- 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.
- 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.BroadcastRecordWriter
-
- randomEmit(T) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
-
- 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
-
- 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
-
- 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, String) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Receives an AcknowledgeCheckpoint message and returns whether the
message was associated with a pending checkpoint.
- receiveDeclineMessage(DeclineCheckpoint, String) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- 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.
- receiveHeartbeat(ResourceID, I) - 类 中的方法org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
-
- reconnect(JobID) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Triggers reconnection to the last known leader of the given job.
- RecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - 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.
- recordModification(ExecutionVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- 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
-
- recordVertexModifications(Collection<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- RecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
-
An abstract record-oriented runtime result writer.
- RecordWriterBuilder<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
-
Utility class to encapsulate the logic of building a
RecordWriter
instance.
- RecordWriterBuilder() - 类 的构造器org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- RecordWriterDelegate<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的接口
-
The record writer delegate provides the availability function for task processor, and it might represent
a single
RecordWriter
or multiple
RecordWriter
instances in specific implementations.
- recover() - 接口 中的方法org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- 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.SingleJobJobGraphStore
-
- recoverJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphStore
-
Returns the
JobGraph
with the given
JobID
or
null
if no job was registered.
- recoverJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- recoverJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- 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(Collection<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
-
- reDistributePartitionableStates(List<OperatorState>, int, List<OperatorID>, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<OperatorStateHandle>>) - 类 中的静态方法org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- 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
-
- RegionPartitionReleaseStrategy - org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease中的类
-
Releases blocking intermediate result partitions that are incident to a
PipelinedRegion
,
as soon as the region's execution vertices are finished.
- RegionPartitionReleaseStrategy(SchedulingTopology<?, ?>, Set<PipelinedRegion>) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy
-
- RegionPartitionReleaseStrategy.Factory - org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease中的类
-
- 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.
- 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
-
- 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
-
- registerInputMetrics(boolean, MetricGroup, SingleInputGate[]) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- 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
-
- registerJobStatusListener(JobStatusListener) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- registerJobStatusListener(JobStatusListener) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
-
- 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.
- registerLegacyNetworkMetrics(boolean, MetricGroup, ResultPartitionWriter[], InputGate[]) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerLegacyNetworkMetrics(MetricGroup, ResultPartitionWriter[], InputGate[]) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- 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.
- registerOutputMetrics(boolean, MetricGroup, ResultPartition[]) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerPartition(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- registerPartitionWithProducer(PartitionDescriptor, ProducerDescriptor) - 枚举 中的方法org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
- registerPartitionWithProducer(PartitionDescriptor, ProducerDescriptor) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleMaster
-
Asynchronously register a partition and its producer with the shuffle service.
- registerProducedPartitions(TaskManagerLocation) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- registerProducedPartitions(TaskManagerLocation, boolean) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- registerQueueLengthMetrics(MetricGroup, SingleInputGate[]) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.InputGateMetrics
-
- registerQueueLengthMetrics(MetricGroup, ResultPartition[]) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.ResultPartitionMetrics
-
- registerReference(SharedStateRegistryKey, StreamStateHandle) - 类 中的方法org.apache.flink.runtime.state.SharedStateRegistry
-
Register a reference to the given shared state in the registry.
- 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.
- registerShuffleMetrics(MetricGroup, NetworkBufferPool) - 类 中的静态方法org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerSlotRequest(SlotRequest) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Requests a slot with the respective resource profile.
- registerSlotRequest(SlotRequest) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
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.
- 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(TaskExecutorRegistration, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
-
- registerTaskExecutor(TaskExecutorRegistration, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- 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
-
- 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.
- registerTaskManager(TaskExecutorConnection, SlotReport) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
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中的类
-
- 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(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
-
- 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.CopyOnWriteStateMapSnapshot
-
- release() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
-
- release() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
-
- release() - 类 中的方法org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Release the snapshot.
- 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.
- releaseAllMemory(Object) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Releases all reserved memory chunks from an owner to this memory manager.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - 类 中的方法org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseAllResources() - 接口 中的方法org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- releaseAllResources() - 类 中的方法org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- 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.SingleJobJobGraphStore
-
- releaseJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphWriter
-
Releases the locks on the specified
JobGraph
.
- releaseJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- releaseJobGraph(JobID) - 枚举 中的方法org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
-
- releaseJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- 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.
- releaseMemory(Object, long) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Releases a memory chunk of a certain size from an owner to this memory manager.
- ReleaseOnConsumptionResultPartition - org.apache.flink.runtime.io.network.partition中的类
-
ResultPartition that releases itself once all subpartitions have been consumed.
- releaseOrPromotePartitions(JobID, Set<ResultPartitionID>, Set<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- releaseOrPromotePartitions(JobID, Set<ResultPartitionID>, Set<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Batch release/promote intermediate result partitions.
- releasePartition(ResultPartitionID, Throwable) - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- releasePartitionExternally(ShuffleDescriptor) - 枚举 中的方法org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
- releasePartitionExternally(ShuffleDescriptor) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleMaster
-
Release any external resources occupied by the given partition.
- releasePartitions(JobID, Set<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Batch release intermediate result partitions.
- releasePartitions(JobID, Set<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- releasePartitionsLocally(Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- releasePartitionsLocally(Collection<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Release local resources occupied by the given partitions.
- 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() - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
-
- releaseSlot(Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.LogicalSlot
-
Releases this slot.
- releaseSlot(SlotRequestId, Throwable) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
-
- releaseSlot(Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- releaseSlot(SlotRequestId, Throwable) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
- 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
-
- 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.
- RemoteChannelStateChecker - org.apache.flink.runtime.io.network.partition.consumer中的类
-
- RemoteChannelStateChecker(ResultPartitionID, String) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
-
- RemoteFencedMessage<F extends Serializable,P extends Serializable> - org.apache.flink.runtime.rpc.messages中的类
-
- 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, int, int, InputChannelMetrics, MemorySegmentProvider) - 类 的构造器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() - 类 中的方法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(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- 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(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- remove(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace.
- 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
-
- removeAndGetOld(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- removeAndGetOld(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- removeAndGetOld(K, N) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace, returning the state that was
found under the entry.
- removeAndGetOld(N) - 类 中的方法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
-
- 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.SingleJobJobGraphStore
-
- removeJobGraph(JobID) - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphWriter
-
Removes the
JobGraph
with the given
JobID
if it exists.
- removeJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- removeJobGraph(JobID) - 枚举 中的方法org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
-
- removeJobGraph(JobID) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- removeKeyA(A) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- removeKeyB(B) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- removeLast() - 类 中的方法org.apache.flink.runtime.util.IntArrayList
-
- removeLong(int) - 类 中的方法org.apache.flink.runtime.util.LongArrayList
-
- removeMetric(Metric) - 类 中的方法org.apache.flink.runtime.metrics.dump.MetricQueryService
-
- 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
-
- removeTask(ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Remove the task with the given execution attempt id from its task slot.
- removeTask(ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- removeTaskMetricGroup(AbstractID) - 类 中的方法org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- removeVertexFromGroup(JobVertexID, ResourceSpec) - 类 中的方法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.
- replaceGracefulExitWithHaltIfConfigured(Configuration) - 类 中的静态方法org.apache.flink.runtime.security.ExitTrappingSecurityManager
-
If configured, registers a custom SecurityManager which converts graceful exists calls using
System#exit
into forceful exit calls using Runtime#halt
.
- reportAllElementKeyGroups() - 类 中的方法org.apache.flink.runtime.state.KeyGroupPartitioner
-
This method iterates over the input data and reports the key-group for each element.
- ReporterScopedSettings - org.apache.flink.runtime.metrics.groups中的类
-
Encapsulates all settings that are defined per reporter.
- ReporterScopedSettings(int, char, Set<String>) - 类 的构造器org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
-
- ReporterSetup - org.apache.flink.runtime.metrics中的类
-
Encapsulates everything needed for the instantiation and configuration of a MetricReporter
.
- ReporterSetup(String, MetricConfig, MetricReporter) - 类 的构造器org.apache.flink.runtime.metrics.ReporterSetup
-
- reportHeartbeat() - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Report heartbeat from the monitored target.
- reportHeartbeat() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- 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.
- reportSlotStatus(InstanceID, SlotReport) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - 接口 中的方法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
-
- requestBackPressure(int, Time) - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
Request the back pressure ratio from the task of this execution.
- 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.
- requestBufferBuilderBlocking() - 接口 中的方法org.apache.flink.runtime.io.network.buffer.BufferProvider
-
- 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.
- requestHeartbeat(ResourceID, I) - 类 中的方法org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
-
- requestJob(JobID, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.dispatcher.DispatcherGateway
-
- requestJob(Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJob(Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestJob() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestJob() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestJob(JobID, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
- 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
-
- requestJobDetails() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestJobDetails() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestJobStatus() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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
-
- requestKvStateLocation(JobID, String) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestKvStateLocation(JobID, String) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestMemorySegment() - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- requestMemorySegments() - 类 中的方法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 gateway of Metric Query Service on the TaskManager.
- requestMetricQueryServiceAddresses(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestMetricQueryServiceAddresses(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
- 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.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile) - 接口 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Requests the allocation of a new batch slot from the resource manager.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- 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
-
- requestNewBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
-
- requestNewBufferBuilder(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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(JobVertexID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestOperatorBackPressureStats(JobVertexID) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestOperatorBackPressureStats(JobID, JobVertexID) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the statistics on operator back pressure.
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider
-
Trigger the producer execution state request.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.taskexecutor.PartitionProducerStateChecker
-
Requests the execution state of the execution producing a result partition.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - 类 中的方法org.apache.flink.runtime.taskmanager.Task
-
- 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.
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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中的类
-
- 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, ResourceProfile, String, ResourceManagerId, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestSlot(SlotID, JobID, AllocationID, ResourceProfile, 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.
- 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.NettyPartitionRequestClient
-
Requests a remote intermediate result partition queue.
- requestSubpartition(int) - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests a remote subpartition.
- requestSubpartition(ResultPartitionID, int, RemoteInputChannel, int) - 接口 中的方法org.apache.flink.runtime.io.network.PartitionRequestClient
-
Requests a remote sub partition.
- 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
-
- requestTaskBackPressure(ExecutionAttemptID, int, Time) - 接口 中的方法org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request the back pressure ratio for the given task.
- requestTaskBackPressure(ExecutionAttemptID, int, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestTaskBackPressure(ExecutionAttemptID, int, Time) - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestTaskBackPressure(ExecutionAttemptID, int, Time) - 接口 中的方法org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- 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
-
- requestTaskManagerInfo(ResourceID, Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - 接口 中的方法org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
- 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
-
- 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
-
- 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中的类
-
- 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中的类
-
- 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中的类
-
- RescalingTriggerMessageParameters() - 类 的构造器org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- reserve(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
-
- reserveMemory(Object, long) - 类 中的方法org.apache.flink.runtime.memory.MemoryManager
-
Reserves a memory chunk of a certain size for an owner from this memory manager.
- 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
-
- resetAvailable() - 类 中的方法org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
- resetConstraints() - 类 中的方法org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- 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.
- resetForNewExecution() - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- resetForNewExecutions(Collection<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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.
- resetUnavailable() - 类 中的方法org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Judges to reset the current available state as unavailable.
- 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
-
- resolve(X) - 类 中的方法org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given value.
- resolveCheckpoint(String) - 接口 中的方法org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
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.CheckpointStorageWorkerView
-
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.
- ResourceBudgetManager - org.apache.flink.runtime.clusterframework.types中的类
-
- ResourceBudgetManager(ResourceProfile) - 类 的构造器org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
-
- 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中的类
-
- 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中的类
-
- ResourceIDSerializer() - 类 的构造器org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
-
- ResourceManager<WorkerType extends ResourceIDRetrievable> - org.apache.flink.runtime.resourcemanager中的类
-
ResourceManager implementation.
- ResourceManager(RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup) - 类 的构造器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中的异常错误
-
- 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中的接口
-
- ResourceManagerId - org.apache.flink.runtime.resourcemanager中的类
-
- ResourceManagerMetricGroup - org.apache.flink.runtime.metrics.groups中的类
-
- ResourceManagerRuntimeServices - org.apache.flink.runtime.resourcemanager中的类
-
- ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - 类 的构造器org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- ResourceManagerRuntimeServicesConfiguration - org.apache.flink.runtime.resourcemanager中的类
-
- 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.Builder - org.apache.flink.runtime.clusterframework.types中的类
-
- resourceProfilesPerWorker - 类 中的变量org.apache.flink.runtime.resourcemanager.ActiveResourceManager
-
- resourceSpecFromConfigForLocalExecution(Configuration) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
-
- 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
-
- 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.
- restart(RestartCallback, ScheduledExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy
-
- restartable(Set<ExecutionVertexID>, long) - 类 中的静态方法org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Creates a result of a set of tasks to restart to recover from the failure.
- RestartAllStrategy - org.apache.flink.runtime.executiongraph.failover.flip1中的类
-
A failover strategy that proposes to restart all vertices when a vertex fails.
- RestartAllStrategy(FailoverTopology<?, ?>) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.flip1.RestartAllStrategy
-
- RestartAllStrategy - org.apache.flink.runtime.executiongraph.failover中的类
-
- 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.flip1中的类
-
- RestartAllStrategy.Factory - org.apache.flink.runtime.executiongraph.failover中的类
-
Factory that instantiates the RestartAllStrategy.
- RestartBackoffTimeStrategy - org.apache.flink.runtime.executiongraph.failover.flip1中的接口
-
Strategy to decide whether to restart failed tasks and the delay to do the restarting.
- RestartBackoffTimeStrategy.Factory - org.apache.flink.runtime.executiongraph.failover.flip1中的接口
-
- RestartBackoffTimeStrategyFactoryLoader - org.apache.flink.runtime.executiongraph.failover.flip1中的类
-
- 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.flip1中的类
-
A failover strategy that proposes to restart involved regions when a vertex fails.
- RestartPipelinedRegionStrategy(FailoverTopology<?, ?>) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionStrategy(FailoverTopology<?, ?>, ResultPartitionAvailabilityChecker) - 类 的构造器org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionStrategy.Factory - org.apache.flink.runtime.executiongraph.failover.flip1中的类
-
- RestartStrategy - org.apache.flink.runtime.executiongraph.restart中的接口
-
- RestartStrategyFactory - org.apache.flink.runtime.executiongraph.restart中的类
-
- RestartStrategyFactory() - 类 的构造器org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- RestartStrategyResolving - org.apache.flink.runtime.executiongraph.restart中的类
-
- restartTasks(Set<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- restartTasks(Set<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy
-
- restartTasks(Set<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy
-
- restartTasks(Set<ExecutionVertexID>) - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called whenever vertices need to be restarted (due to task failure).
- 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中的类
-
- RestClient(RestClientConfiguration, Executor) - 类 的构造器org.apache.flink.runtime.rest.RestClient
-
- RestClientConfiguration - org.apache.flink.runtime.rest中的类
-
- 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, boolean) - 类 的构造器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
-
已过时。
- restoreLatestCheckpointedState(Set<ExecutionJobVertex>, boolean, boolean) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
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.
- restoreState(Set<ExecutionVertexID>) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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中的类
-
- Result(StreamStateHandle, int) - 类 的构造器org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- Result<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> - org.apache.flink.runtime.topology中的接口
-
Represents a data set produced by a
Vertex
Each result is produced by one
Vertex
.
- resultHandler - 类 中的变量org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handler for completed requests
- ResultID - org.apache.flink.runtime.topology中的接口
-
- ResultPartition - org.apache.flink.runtime.io.network.partition中的类
-
A result partition for data produced by a single task.
- ResultPartition(String, ResultPartitionID, ResultPartitionType, ResultSubpartition[], int, ResultPartitionManager, BufferCompressor, FunctionWithException<BufferPoolOwner, BufferPool, IOException>) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartition
-
- ResultPartitionAvailabilityChecker - org.apache.flink.runtime.executiongraph.failover.flip1中的接口
-
This checker helps to query result partition availability.
- 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(PartitionDescriptor, ShuffleDescriptor, int, boolean) - 类 的构造器org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- ResultPartitionFactory - org.apache.flink.runtime.io.network.partition中的类
-
- ResultPartitionFactory(ResultPartitionManager, FileChannelManager, BufferPoolFactory, BoundedBlockingSubpartitionType, int, int, int, boolean, boolean, String) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- ResultPartitionID - org.apache.flink.runtime.io.network.partition中的类
-
- ResultPartitionID() - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- ResultPartitionID(IntermediateResultPartitionID, ExecutionAttemptID) - 类 的构造器org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- 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.metrics中的类
-
Collects metrics of a result partition.
- ResultPartitionProvider - org.apache.flink.runtime.io.network.partition中的接口
-
Interface for creating result partitions.
- ResultPartitionState - org.apache.flink.runtime.scheduler.strategy中的枚举
-
- 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中的类
-
- 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中的接口
-
- 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
-
- 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中的接口
-
- 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
-
- retrieveLeaderConnectionInfo(LeaderRetrievalService, Duration) - 类 中的静态方法org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader akka url and the current leader session ID.
- 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.RpcMetricQueryServiceRetriever
-
- retrieveService(String) - 接口 中的方法org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
-
- 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.
- 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.
- 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中的类
-
- 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.runner.DefaultDispatcherRunner
-
- revokeLeadership() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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
-
- rng - 类 中的变量org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- ROCKSDB_STATE_BACKEND_NAME - 类 中的静态变量org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name for the RocksDB State Backend
- RoundRobinChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
-
- RoundRobinChannelSelector() - 类 的构造器org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- RoundRobinOperatorStateRepartitioner - org.apache.flink.runtime.checkpoint中的类
-
- 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中的类
-
- 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中的类
-
- RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - 类 的构造器org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
-
- RpcMetricQueryServiceRetriever - org.apache.flink.runtime.webmonitor.retriever.impl中的类
-
- RpcMetricQueryServiceRetriever(RpcService) - 类 的构造器org.apache.flink.runtime.webmonitor.retriever.impl.RpcMetricQueryServiceRetriever
-
- 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中的类
-
- 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.heartbeat.HeartbeatMonitorImpl
-
- 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
-
- 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.
- Runnables - org.apache.flink.runtime.util中的类
-
- Runnables() - 类 的构造器org.apache.flink.runtime.util.Runnables
-
- 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
-
- runTaskManagerSecurely(String[], ResourceID) - 类 中的静态方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- runTaskManagerSecurely(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中的类
-
- 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.
- sampleTaskBackPressure(BackPressureSampleableTask) - 类 中的方法org.apache.flink.runtime.taskexecutor.BackPressureSampleService
-
Schedules to sample the task back pressure and returns a future that completes
with the back pressure ratio.
- Savepoint - org.apache.flink.runtime.checkpoint.savepoint中的接口
-
Savepoints are manually-triggered snapshots from which a program can be
resumed on submission.
- SAVEPOINT_IGNORE_UNCLAIMED_STATE - 类 中的静态变量org.apache.flink.runtime.jobgraph.SavepointConfigOptions
-
A flag indicating if we allow Flink to skip savepoint state that cannot be restored,
e.g. because the corresponding operator has been removed.
- SAVEPOINT_PATH - 类 中的静态变量org.apache.flink.runtime.jobgraph.SavepointConfigOptions
-
The path to a savepoint that will be used to bootstrap the pipeline's state.
- SavepointConfigOptions - org.apache.flink.runtime.jobgraph中的类
-
The configuration options
used when restoring from a savepoint.
- SavepointConfigOptions() - 类 的构造器org.apache.flink.runtime.jobgraph.SavepointConfigOptions
-
- 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中的类
-
- SavepointDisposalStatusMessageParameters - org.apache.flink.runtime.rest.messages.job.savepoints中的类
-
- 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中的类
-
- 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.
- SavepointHandlers.StopWithSavepointHandler - org.apache.flink.runtime.rest.handler.job.savepoints中的类
-
HTTP handler to stop a job with a savepoint.
- 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中的接口
-
- SavepointSerializers - org.apache.flink.runtime.checkpoint.savepoint中的类
-
- 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中的类
-
- 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
-
- 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(ScheduleMode, Iterable<ExecutionVertex>, ExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.executiongraph.SchedulingUtils
-
- schedule(Runnable, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- schedule(Callable<V>, long, TimeUnit) - 类 中的方法org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- 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中的类
-
- ScheduledExecutorServiceAdapter(ScheduledExecutorService) - 类 的构造器org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- ScheduledFutureAdapter<V> - org.apache.flink.runtime.concurrent中的类
-
- 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
-
- scheduleEager(Iterable<ExecutionVertex>, ExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.executiongraph.SchedulingUtils
-
Schedule vertices eagerly.
- scheduleForExecution() - 类 中的方法org.apache.flink.runtime.executiongraph.Execution
-
- scheduleForExecution(SlotProviderStrategy, 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(SlotProviderStrategy, LocationPreferenceConstraint, Set<AllocationID>) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Schedules the current execution of this ExecutionVertex.
- scheduleLazy(Iterable<ExecutionVertex>, ExecutionGraph) - 类 中的静态方法org.apache.flink.runtime.executiongraph.SchedulingUtils
-
Schedule vertices lazy.
- 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.
- scheduleOrUpdateConsumers(ResultPartitionID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- scheduleOrUpdateConsumers(ResultPartitionID) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- scheduleOrUpdateConsumersInternal(ExecutionVertexID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.scheduler.DefaultScheduler
-
- scheduleOrUpdateConsumersInternal(ExecutionVertexID, ResultPartitionID) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- Scheduler - org.apache.flink.runtime.jobmaster.slotpool中的接口
-
- SCHEDULER_TYPE_LEGACY - 类 中的静态变量org.apache.flink.runtime.dispatcher.SchedulerNGFactoryFactory
-
- SCHEDULER_TYPE_NG - 类 中的静态变量org.apache.flink.runtime.dispatcher.SchedulerNGFactoryFactory
-
- SchedulerBase - org.apache.flink.runtime.scheduler中的类
-
- SchedulerBase(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategyFactory, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionVertexVersioner, boolean) - 类 的构造器org.apache.flink.runtime.scheduler.SchedulerBase
-
- SchedulerFactory - org.apache.flink.runtime.jobmaster.slotpool中的接口
-
- 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
-
- SchedulerNG - org.apache.flink.runtime.scheduler中的接口
-
Interface for scheduling Flink jobs.
- SchedulerNGFactory - org.apache.flink.runtime.scheduler中的接口
-
- SchedulerNGFactoryFactory - org.apache.flink.runtime.dispatcher中的类
-
- SchedulerOperations - org.apache.flink.runtime.scheduler中的接口
-
- 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.
- scheduleWithDelay(Runnable, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
-
Schedule the operation with the given delay.
- scheduleWithDelay(Supplier<T>, Time, ScheduledExecutor) - 类 中的静态方法org.apache.flink.runtime.concurrent.FutureUtils
-
Schedule the operation with the given 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
-
- SchedulingExecutionVertex<V extends SchedulingExecutionVertex<V,R>,R extends SchedulingResultPartition<V,R>> - org.apache.flink.runtime.scheduler.strategy中的接口
-
- SchedulingResultPartition<V extends SchedulingExecutionVertex<V,R>,R extends SchedulingResultPartition<V,R>> - org.apache.flink.runtime.scheduler.strategy中的接口
-
- SchedulingStrategy - org.apache.flink.runtime.scheduler.strategy中的接口
-
Component which encapsulates the scheduling logic.
- SchedulingStrategyFactory - org.apache.flink.runtime.scheduler.strategy中的接口
-
- SchedulingTopology<V extends SchedulingExecutionVertex<V,R>,R extends SchedulingResultPartition<V,R>> - org.apache.flink.runtime.scheduler.strategy中的接口
-
- SchedulingUtils - org.apache.flink.runtime.executiongraph中的类
-
This class contains scheduling logic for EAGER and LAZY_FROM_SOURCES.
- SchedulingUtils() - 类 的构造器org.apache.flink.runtime.executiongraph.SchedulingUtils
-
- 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中的接口
-
- 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<SlotSelectionStrategy.SlotInfoAndResources>, SlotProfile) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- selectBestSlotForProfile(Collection<SlotSelectionStrategy.SlotInfoAndResources>, SlotProfile) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
- selectBestSlotForProfile(Collection<SlotSelectionStrategy.SlotInfoAndResources>, 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
-
- selectWithoutLocationPreference(Collection<SlotSelectionStrategy.SlotInfoAndResources>, ResourceProfile) - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- 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.
- 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.
- sendScheduleOrUpdateConsumerMessage() - 类 中的方法org.apache.flink.runtime.scheduler.DeploymentOption
-
- 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.NettyPartitionRequestClient
-
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
-
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - 接口 中的方法org.apache.flink.runtime.io.network.PartitionRequestClient
-
Sends a task event backwards to an intermediate result partition.
- sendTaskEvent(TaskEvent) - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- 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中的类
-
- 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.io.network.api.writer.RecordWriter
-
- 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
-
- 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中的枚举
-
- SessionDispatcherLeaderProcess - org.apache.flink.runtime.dispatcher.runner中的类
-
Process which encapsulates the job recovery logic and life cycle management of a
Dispatcher
.
- SessionDispatcherLeaderProcessFactoryFactory - org.apache.flink.runtime.dispatcher.runner中的类
-
Factory for the SessionDispatcherLeaderProcessFactory
.
- SessionRestEndpointFactory - org.apache.flink.runtime.rest中的枚举
-
- set(int) - 类 中的方法org.apache.flink.runtime.operators.util.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
-
- 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
-
- setBlobServerAddress(InetSocketAddress) - 类 中的方法org.apache.flink.runtime.blob.BlobCacheService
-
- 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
-
- setChannelSelector(ChannelSelector<T>) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- 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
-
- setCompressed(boolean) - 接口 中的方法org.apache.flink.runtime.io.network.buffer.Buffer
-
Tags the buffer as compressed or uncompressed.
- setCompressed(boolean) - 类 中的方法org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setCompressed(boolean) - 类 中的方法org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- 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
-
- setCpuCores(Resource) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setCpuCores(double) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setCurrentKey(K) - 类 中的方法org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- setCurrentKey(K) - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
-
Set current key of the context.
- setCurrentKey(K) - 类 中的方法org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- setCurrentKey(K) - 接口 中的方法org.apache.flink.runtime.state.KeyedStateBackend
-
Sets the current key that is used for partitioned state.
- setCurrentKeyGroupIndex(int) - 接口 中的方法org.apache.flink.runtime.state.heap.InternalKeyContext
-
Set current key group index of the context.
- setCurrentKeyGroupIndex(int) - 类 中的方法org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- 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
-
- setFailUnfulfillableRequest(boolean) - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
-
Set
SlotManager
whether to fail unfulfillable slot requests.
- setFailUnfulfillableRequest(boolean) - 接口 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- setFailUnfulfillableRequest(boolean) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- 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
-
- setFencingToken(F) - 类 中的方法org.apache.flink.runtime.rpc.PermanentlyFencedRpcEndpoint
-
- 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(OperatorID, String) - 类 中的方法org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- setFurtherPatitioning(boolean) - 类 中的方法org.apache.flink.runtime.operators.hash.HashPartition
-
- setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- setGlobalFailureCause(Throwable) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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
-
- 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.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
-
- setJobID(JobID) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the ID of the job.
- 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
.
- setMainThreadExecutor(ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- setMainThreadExecutor(ComponentMainThreadExecutor) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- setManagedMemory(MemorySize) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setManagedMemoryMB(int) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- 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
-
- 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.
- setNetworkMemory(MemorySize) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setNetworkMemoryMB(int) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- 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.
- 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.jobgraph.JobGraph
-
- 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
-
- 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
-
- 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.CopyOnWriteStateMap.StateMapEntry
-
- 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
-
- setTaskHeapMemory(MemorySize) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setTaskHeapMemoryMB(int) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setTaskName(String) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- setTaskName(String) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- setTaskOffHeapMemory(MemorySize) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setTaskOffHeapMemoryMB(int) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
- setThreadPriority(int) - 类 中的方法org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setTimeout(long) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- 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() - 接口 中的方法org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Setup partition, potentially heavy-weight, blocking operation comparing to just creation.
- setup(int) - 类 中的方法org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- setup() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Setup gate, potentially heavy-weight, blocking operation comparing to just creation.
- setup() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setup() - 类 中的方法org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- setup() - 类 中的方法org.apache.flink.runtime.io.network.partition.ResultPartition
-
Registers a buffer pool with this result partition.
- 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.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
-
- setup() - 类 中的方法org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- setup() - 类 中的方法org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- setupPartitionsAndGates(ResultPartitionWriter[], InputGate[]) - 类 中的静态方法org.apache.flink.runtime.taskmanager.Task
-
- setUseLargeRecordHandler(boolean) - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- setUserArtifactBlobKey(String, PermanentBlobKey) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
-
- setUserArtifactRemotePath(String, String) - 类 中的方法org.apache.flink.runtime.jobgraph.JobGraph
-
- setUsrLibDirectory(File) - 类 中的方法org.apache.flink.runtime.clusterframework.overlays.UserLibOverlay.Builder
-
- setValue(byte[]) - 类 中的方法org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- setWaitForSolutionSetUpdate() - 类 中的方法org.apache.flink.runtime.operators.util.TaskConfig
-
- setWritePosition(long) - 类 中的方法org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- 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中的接口
-
- 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.
- shouldDrain() - 类 中的方法org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- 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.
- SHUFFLE_SERVICE_FACTORY_CLASS - 类 中的静态变量org.apache.flink.runtime.shuffle.ShuffleServiceOptions
-
The full class name of the shuffle service factory implementation to be used by the cluster.
- ShuffleDescriptor - org.apache.flink.runtime.shuffle中的接口
-
Interface for shuffle deployment descriptor of result partition resource.
- ShuffleEnvironment<P extends ResultPartitionWriter,G extends InputGate> - org.apache.flink.runtime.shuffle中的接口
-
Interface for the implementation of shuffle service local environment.
- ShuffleEnvironmentContext - org.apache.flink.runtime.shuffle中的类
-
- ShuffleEnvironmentContext(Configuration, ResourceID, MemorySize, boolean, InetAddress, TaskEventPublisher, MetricGroup, Executor) - 类 的构造器org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- ShuffleIOOwnerContext - org.apache.flink.runtime.shuffle中的类
-
Context of shuffle input/output owner used to create partitions or gates belonging to the owner.
- ShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup, MetricGroup, MetricGroup) - 类 的构造器org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- ShuffleMaster<T extends ShuffleDescriptor> - org.apache.flink.runtime.shuffle中的接口
-
Intermediate result partition registry to use in
JobMaster
.
- ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends InputGate> - org.apache.flink.runtime.shuffle中的接口
-
Interface for shuffle service factory implementations.
- ShuffleServiceLoader - org.apache.flink.runtime.shuffle中的枚举
-
- ShuffleServiceOptions - org.apache.flink.runtime.shuffle中的类
-
Options to configure shuffle service.
- ShuffleUtils - org.apache.flink.runtime.shuffle中的类
-
Common utility methods for shuffle service.
- shutdown(JobStatus) - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Shuts down the checkpoint coordinator.
- shutdown(JobStatus) - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- 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.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.partition.ResultPartitionManager
-
- shutdown() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- 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.BackPressureRequestCoordinator
-
Shuts down the coordinator.
- 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(Time) - 类 中的方法org.apache.flink.runtime.rest.RestClient
-
- shutdown() - 类 中的方法org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- shutdown() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- shutDown() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- shutdown() - 类 中的方法org.apache.flink.runtime.taskmanager.MemoryLogger
-
- shutDownCluster() - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- shutDownCluster() - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
- shutDownFuture - 类 中的变量org.apache.flink.runtime.dispatcher.Dispatcher
-
- 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中的类
-
- 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
-
- 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
-
- 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, IntermediateDataSetID, ResultPartitionType, int, int, PartitionProducerStateProvider, SupplierWithException<BufferPool, IOException>, BufferDecompressor) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- SingleInputGateFactory - org.apache.flink.runtime.io.network.partition.consumer中的类
-
- SingleInputGateFactory(ResourceID, NettyShuffleEnvironmentConfiguration, ConnectionManager, ResultPartitionManager, TaskEventPublisher, NetworkBufferPool) - 类 的构造器org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
-
- SingleJobJobGraphStore - org.apache.flink.runtime.dispatcher中的类
-
- SingleJobJobGraphStore(JobGraph) - 类 的构造器org.apache.flink.runtime.dispatcher.SingleJobJobGraphStore
-
- SingleLogicalSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
-
- SingleLogicalSlot(SlotRequestId, SlotContext, SlotSharingGroupId, Locality, SlotOwner) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- SingleRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - org.apache.flink.runtime.io.network.api.writer中的类
-
The specific delegate implementation for the single output case.
- SingleRecordWriter(RecordWriter<T>) - 类 的构造器org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
-
- 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
-
- size() - 类 中的方法org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- size() - 类 中的方法org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- size() - 类 中的方法org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- 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.DefaultExecutionGraphCache
-
- 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.CopyOnWriteStateMap
-
- size() - 类 中的方法org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- size() - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- size() - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Returns the total number of entries in this
StateMap
.
- 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.CopyOnWriteStateMap
-
- sizeOfNamespace(Object) - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- sizeOfNamespace(Object) - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
- 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
-
- SlotActions - org.apache.flink.runtime.taskexecutor.slot中的接口
-
- 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
-
- SlotContext - org.apache.flink.runtime.jobmaster中的接口
-
- SlotExecutionVertexAssignment - org.apache.flink.runtime.scheduler中的类
-
- SlotExecutionVertexAssignment(ExecutionVertexID, CompletableFuture<LogicalSlot>) - 类 的构造器org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- 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.
- SlotInfoAndResources(SlotInfo, ResourceProfile, double) - 类 的构造器org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- SlotInfoWithUtilization - org.apache.flink.runtime.jobmaster.slotpool中的类
-
Container for
SlotInfo
and the task executors utilization (freeSlots / totalOfferedSlots).
- 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.
- SlotManagerConfiguration - org.apache.flink.runtime.resourcemanager.slotmanager中的类
-
- SlotManagerConfiguration(Time, Time, Time, boolean, 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
-
- SlotManagerException(Throwable) - 异常错误 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotManagerImpl - org.apache.flink.runtime.resourcemanager.slotmanager中的类
-
- SlotManagerImpl(SlotMatchingStrategy, ScheduledExecutor, Time, Time, Time, boolean) - 类 的构造器org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- SlotMatchingStrategy - org.apache.flink.runtime.resourcemanager.slotmanager中的接口
-
Strategy how to find a matching slot.
- 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中的接口
-
- SlotPoolImpl - org.apache.flink.runtime.jobmaster.slotpool中的类
-
- SlotPoolImpl(JobID, Clock, Time, 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.
- SlotPoolImpl.PendingRequest - org.apache.flink.runtime.jobmaster.slotpool中的类
-
A pending request for a slot.
- SlotProfile - org.apache.flink.runtime.clusterframework.types中的类
-
A slot profile describes the profile of a slot into which a task wants to be scheduled.
- slotProvider - 类 中的变量org.apache.flink.runtime.executiongraph.SlotProviderStrategy
-
- SlotProvider - org.apache.flink.runtime.jobmaster.slotpool中的接口
-
The slot provider is responsible for preparing slots for ready-to-run tasks.
- SlotProviderStrategy - org.apache.flink.runtime.executiongraph中的类
-
Strategy to switch between different
SlotProvider
allocation strategies.
- 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中的类
-
- SlotSelectionStrategy.SlotInfoAndResources - org.apache.flink.runtime.jobmaster.slotpool中的类
-
- 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
-
- 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.SingleTaskSlot - org.apache.flink.runtime.jobmaster.slotpool中的类
-
- 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
-
- 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中的类
-
- 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中的类
-
- 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, 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中的类
-
- SSLUtils - org.apache.flink.runtime.net中的类
-
Common utilities to manage SSL transport settings.
- SSLUtils() - 类 的构造器org.apache.flink.runtime.net.SSLUtils
-
- StandaloneCheckpointIDCounter - org.apache.flink.runtime.checkpoint中的类
-
- StandaloneCheckpointIDCounter() - 类 的构造器org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- StandaloneCheckpointRecoveryFactory - org.apache.flink.runtime.checkpoint中的类
-
- StandaloneCheckpointRecoveryFactory() - 类 的构造器org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- StandaloneClientHAServices - org.apache.flink.runtime.highavailability.nonha.standalone中的类
-
- StandaloneClientHAServices(String) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneClientHAServices
-
- 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, DispatcherId, Collection<JobGraph>, DispatcherServices) - 类 的构造器org.apache.flink.runtime.dispatcher.StandaloneDispatcher
-
- StandaloneHaServices - org.apache.flink.runtime.highavailability.nonha.standalone中的类
-
- StandaloneHaServices(String, String, String, String) - 类 的构造器org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
Creates a new services class for the fix pre-defined leaders.
- StandaloneJobGraphStore - org.apache.flink.runtime.jobmanager中的类
-
- StandaloneJobGraphStore() - 类 的构造器org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- StandaloneLeaderElectionService - org.apache.flink.runtime.leaderelection中的类
-
- StandaloneLeaderElectionService() - 类 的构造器org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- StandaloneLeaderRetrievalService - org.apache.flink.runtime.leaderretrieval中的类
-
- 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, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup, Time) - 类 的构造器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
-
- StandaloneUtils - org.apache.flink.runtime.util中的类
-
Utility class to work with Flink standalone mode.
- start() - 接口 中的方法org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
- start() - 类 中的方法org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- start() - 类 中的方法org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- start() - 枚举 中的方法org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
- start(JobGraphStore.JobGraphListener) - 类 中的方法org.apache.flink.runtime.dispatcher.SingleJobJobGraphStore
-
- start(ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- start() - 接口 中的方法org.apache.flink.runtime.io.network.ConnectionManager
-
Starts the internal related components for network connection and communication.
- start() - 类 中的方法org.apache.flink.runtime.io.network.LocalConnectionManager
-
- start() - 类 中的方法org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- start() - 类 中的方法org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- start(JobGraphStore.JobGraphListener) - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphStore
-
- start(JobGraphStore.JobGraphListener) - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- start(JobGraphStore.JobGraphListener) - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- start() - 接口 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- start() - 类 中的方法org.apache.flink.runtime.jobmaster.JobManagerRunnerImpl
-
- 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.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(ResourceManagerId, Executor, ResourceActions) - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
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
-
Triggers start of the rpc endpoint.
- start() - 接口 中的方法org.apache.flink.runtime.rpc.StartStoppable
-
Starts the processing of remote procedure calls.
- start() - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Start the internal related services before using the shuffle service environment.
- start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Start the job leader service with the given services.
- start() - 类 中的方法org.apache.flink.runtime.taskexecutor.KvStateService
-
- start(SlotActions, ComponentMainThreadExecutor) - 接口 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Start the task slot table with the given slot actions.
- start(SlotActions, ComponentMainThreadExecutor) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
-
- start(TimeoutListener<K>) - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- start() - 类 中的方法org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- 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, CompletableFuture<Void>) - 类 中的静态方法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
-
- startMetricsRpcService(Configuration, String) - 类 中的静态方法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(RpcService, 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.
- startScheduling() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- startScheduling() - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- startScheduling() - 类 中的方法org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy
-
- startScheduling() - 类 中的方法org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy
-
- startScheduling() - 接口 中的方法org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called when the scheduling is started (initial scheduling operation).
- startSchedulingInternal() - 类 中的方法org.apache.flink.runtime.scheduler.DefaultScheduler
-
- startSchedulingInternal() - 类 中的方法org.apache.flink.runtime.scheduler.LegacyScheduler
-
- startSchedulingInternal() - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- 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.
- startServicesOnLeadership() - 类 中的方法org.apache.flink.runtime.resourcemanager.ResourceManager
-
- startServicesOnLeadership() - 类 中的方法org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- 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.
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - 接口 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Starts the tracking of the given partition for the given task executor ID.
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - 类 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
-
- startTrackingPartition(JobID, TaskExecutorPartitionInfo) - 接口 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Starts the tracking of the given partition for the given job.
- startTrackingPartition(JobID, TaskExecutorPartitionInfo) - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
-
- startTrackingPartitions(K, Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Starts the tracking of the given partition for the given key.
- 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, Set<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.
- stateChanged(CuratorFramework, ConnectionState) - 类 中的方法org.apache.flink.runtime.checkpoint.DefaultLastStateConnectionStateListener
-
- 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中的类
-
- 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
- StateMap<K,N,S> - org.apache.flink.runtime.state.heap中的类
-
Base class for state maps.
- StateMap() - 类 的构造器org.apache.flink.runtime.state.heap.StateMap
-
- StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> - org.apache.flink.runtime.state.heap中的类
-
- StateMapSnapshot(T) - 类 的构造器org.apache.flink.runtime.state.heap.StateMapSnapshot
-
- StateMetaInfo(long[], OperatorStateHandle.Mode) - 类 的构造器org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- StateMetaInfoReader - org.apache.flink.runtime.state.metainfo中的接口
-
- 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
-
- 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中的类
-
- StateMetaInfoSnapshotReadersWriters.StateTypeHint - org.apache.flink.runtime.state.metainfo中的枚举
-
Enum for backwards compatibility.
- StateMetaInfoWriter - org.apache.flink.runtime.state.metainfo中的接口
-
- 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
StateObject
s.
- 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
-
- stateSerializer - 类 中的变量org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
The serializer of the state.
- 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.CopyOnWriteStateMap
-
- stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
- stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.NestedStateMap
-
- stateSnapshot() - 类 中的方法org.apache.flink.runtime.state.heap.StateMap
-
Creates a snapshot of this
StateMap
, to be written in checkpointing.
- 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
StateTable
s 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>, TypeSerializer<K>) - 类 的构造器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中的类
-
- 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
-
- 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.SingleJobJobGraphStore
-
- stop() - 接口 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Stops the heartbeat manager.
- stop() - 类 中的方法org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- stop() - 类 中的方法org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
-
- stop() - 接口 中的方法org.apache.flink.runtime.jobmanager.JobGraphStore
-
- stop() - 类 中的方法org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
-
- stop() - 类 中的方法org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStore
-
- 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.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
-
Triggers stop of the rpc endpoint.
- stop() - 接口 中的方法org.apache.flink.runtime.rpc.StartStoppable
-
Stops the processing of remote procedure calls.
- stop() - 类 中的方法org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator
-
- stop() - 接口 中的方法org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Stop the allocator.
- stop() - 类 中的方法org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Stop the job leader services.
- stop() - 类 中的方法org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- stopCheckpointScheduler() - 类 中的方法org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- stopClusterServices(boolean) - 类 中的方法org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- stopped - 类 中的变量org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
Running state of the heartbeat manager.
- StoppedDispatcherLeaderProcess - org.apache.flink.runtime.dispatcher.runner中的枚举
-
DispatcherLeaderProcess
implementation which is stopped.
- 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
.
- stopTrackingAndReleaseAllClusterPartitions() - 接口 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases and stops tracking all partitions.
- stopTrackingAndReleaseAllClusterPartitions() - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
-
- stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
-
- stopTrackingAndReleaseJobPartitionsFor(JobID) - 接口 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases all partitions for the given job and stop the tracking of partitions that were released.
- stopTrackingAndReleaseJobPartitionsFor(JobID) - 类 中的方法org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
-
- stopTrackingAndReleaseOrPromotePartitionsFor(ResourceID) - 接口 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Releases all job partitions and promotes all cluster partitions for the given task executor ID, and stops the tracking of partitions that were released/promoted.
- stopTrackingAndReleaseOrPromotePartitionsFor(ResourceID) - 类 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
-
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
-
- stopTrackingAndReleasePartitionsFor(ResourceID) - 接口 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Releases all partitions for the given task executor ID, and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitionsFor(ResourceID) - 类 中的方法org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
-
- stopTrackingPartitions(Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
-
- stopTrackingPartitions(Collection<ResultPartitionID>) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of the given partitions.
- stopTrackingPartitions(K) - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of all partition for the given key.
- stopTrackingPartitions(K, Collection<ResultPartitionID>) - 类 中的方法org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of the given set of partitions for the given key.
- stopTrackingPartitionsFor(K) - 类 中的方法org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
-
- stopTrackingPartitionsFor(K) - 接口 中的方法org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of all partitions for the given key.
- stopWithSavepoint(JobID, String, boolean, Time) - 类 中的方法org.apache.flink.runtime.dispatcher.Dispatcher
-
- stopWithSavepoint(String, boolean, Time) - 类 中的方法org.apache.flink.runtime.jobmaster.JobMaster
-
- stopWithSavepoint(String, boolean, Time) - 接口 中的方法org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Stops the job with a savepoint.
- stopWithSavepoint(JobID, String, boolean) - 类 中的方法org.apache.flink.runtime.minicluster.MiniCluster
-
- stopWithSavepoint(String, boolean) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- stopWithSavepoint(String, boolean) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- stopWithSavepoint(JobID, String, boolean, Time) - 接口 中的方法org.apache.flink.runtime.webmonitor.RestfulGateway
-
Stops the job with a savepoint.
- StopWithSavepointHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - 类 的构造器org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.StopWithSavepointHandler
-
- StopWithSavepointRequestBody - org.apache.flink.runtime.rest.messages.job.savepoints.stop中的类
-
- StopWithSavepointRequestBody(String, boolean) - 类 的构造器org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- StopWithSavepointTriggerHeaders - org.apache.flink.runtime.rest.messages.job.savepoints.stop中的类
-
These headers define the protocol for triggering a "stop" action.
- 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
-
- storesLocalResourcesOn() - 类 中的方法org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- storesLocalResourcesOn() - 接口 中的方法org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns the location of the producing task executor if the partition occupies local resources there.
- storesLocalResourcesOn() - 类 中的方法org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- 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.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
-
- subpartitions - 类 中的变量org.apache.flink.runtime.io.network.partition.ResultPartition
-
The subpartitions of this partition.
- 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中的类
-
- 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中的类
-
- 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, String) - 类 的构造器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中的类
-
- SubtasksAllAccumulatorsInfo - org.apache.flink.runtime.rest.messages.job中的类
-
- 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中的类
-
- 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中的类
-
- SubtasksTimesHeaders() - 类 的构造器org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- SubtasksTimesInfo - org.apache.flink.runtime.rest.messages中的类
-
- 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
-
- subtract(ResourceProfile) - 类 中的方法org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Subtracts another piece of resource profile from this one.
- Success() - 类 的构造器org.apache.flink.runtime.registration.RegistrationResponse.Success
-
- SUFFIX_RATE - 类 中的静态变量org.apache.flink.runtime.metrics.MetricNames
-
- 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.CheckpointStorageCoordinatorView
-
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.
- suspend() - 类 中的方法org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Suspends the component.
- suspend(Throwable) - 类 中的方法org.apache.flink.runtime.scheduler.SchedulerBase
-
- suspend(Throwable) - 接口 中的方法org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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中的类
-
- 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
-