Modifier and Type | Method and Description |
---|---|
Time |
RestartStrategies.FixedDelayRestartStrategyConfiguration.getDelayBetweenAttemptsInterval() |
Time |
RestartStrategies.FailureRateRestartStrategyConfiguration.getDelayBetweenAttemptsInterval() |
Time |
RestartStrategies.FailureRateRestartStrategyConfiguration.getFailureInterval() |
Modifier and Type | Method and Description |
---|---|
static RestartStrategies.FailureRateRestartStrategyConfiguration |
RestartStrategies.failureRateRestart(int failureRate,
Time failureInterval,
Time delayInterval)
Generates a FailureRateRestartStrategyConfiguration.
|
static RestartStrategies.RestartStrategyConfiguration |
RestartStrategies.fixedDelayRestart(int restartAttempts,
Time delayInterval)
Generates a FixedDelayRestartStrategyConfiguration.
|
Constructor and Description |
---|
FailureRateRestartStrategyConfiguration(int maxFailureRate,
Time failureInterval,
Time delayBetweenAttemptsInterval) |
Modifier and Type | Method and Description |
---|---|
Time |
StateTtlConfig.getTtl() |
Modifier and Type | Method and Description |
---|---|
static StateTtlConfig.Builder |
StateTtlConfig.newBuilder(Time ttl) |
StateTtlConfig.Builder |
StateTtlConfig.Builder.setTtl(Time ttl)
Sets the ttl time.
|
Constructor and Description |
---|
Builder(Time ttl) |
Modifier and Type | Method and Description |
---|---|
static Time |
Time.days(long days)
Creates a new
Time that represents the given number of days. |
static Time |
Time.hours(long hours)
Creates a new
Time that represents the given number of hours. |
static Time |
Time.milliseconds(long milliseconds)
Creates a new
Time that represents the given number of milliseconds. |
static Time |
Time.minutes(long minutes)
Creates a new
Time that represents the given number of minutes. |
static Time |
Time.of(long size,
TimeUnit unit)
|
static Time |
Time.seconds(long seconds)
Creates a new
Time that represents the given number of seconds. |
Modifier and Type | Method and Description |
---|---|
static Time |
ConfigurationUtils.getStandaloneClusterStartupPeriodTime(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static Optional<Time> |
ConfigurationUtils.getSystemResourceMetricsProbingInterval(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Time |
KubernetesResourceManagerConfiguration.getPodCreationRetryInterval() |
Constructor and Description |
---|
KubernetesResourceManagerConfiguration(String clusterId,
Time podCreationRetryInterval) |
Modifier and Type | Method and Description |
---|---|
static <T> CompletableFuture<T> |
FutureUtils.retrySuccessfulWithDelay(java.util.function.Supplier<CompletableFuture<T>> operation,
Time retryDelay,
Deadline deadline,
java.util.function.Predicate<T> acceptancePredicate,
ScheduledExecutor scheduledExecutor)
Retry the given operation with the given delay in between successful completions where the
result does not match a given predicate.
|
static <T> CompletableFuture<T> |
FutureUtils.retryWithDelay(java.util.function.Supplier<CompletableFuture<T>> operation,
int retries,
Time retryDelay,
java.util.function.Predicate<Throwable> retryPredicate,
ScheduledExecutor scheduledExecutor)
Retry the given operation with the given delay in between failures.
|
static <T> CompletableFuture<T> |
FutureUtils.retryWithDelay(java.util.function.Supplier<CompletableFuture<T>> operation,
int retries,
Time retryDelay,
ScheduledExecutor scheduledExecutor)
Retry the given operation with the given delay in between failures.
|
static CompletableFuture<Void> |
FutureUtils.scheduleWithDelay(Runnable operation,
Time delay,
ScheduledExecutor scheduledExecutor)
Schedule the operation with the given delay.
|
static <T> CompletableFuture<T> |
FutureUtils.scheduleWithDelay(java.util.function.Supplier<T> operation,
Time delay,
ScheduledExecutor scheduledExecutor)
Schedule the operation with the given delay.
|
static java.time.Duration |
FutureUtils.toDuration(Time time)
Converts Flink time into a
Duration . |
Constructor and Description |
---|
FileArchivedExecutionGraphStore(File rootDir,
Time expirationTime,
int maximumCapacity,
long maximumCacheSizeBytes,
ScheduledExecutor scheduledExecutor,
org.apache.flink.shaded.guava18.com.google.common.base.Ticker ticker) |
Modifier and Type | Method and Description |
---|---|
Time |
ExecutionGraph.getAllocationTimeout() |
Modifier and Type | Method and Description |
---|---|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker)
Builds the ExecutionGraph from the JobGraph.
|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
FailoverStrategy.Factory failoverStrategyFactory) |
static SlotProviderStrategy |
SlotProviderStrategy.from(ScheduleMode scheduleMode,
SlotProvider slotProvider,
Time allocationTimeout) |
CompletableFuture<TaskBackPressureResponse> |
Execution.requestBackPressure(int requestId,
Time timeout)
Request the back pressure ratio from the task of this execution.
|
Constructor and Description |
---|
Execution(Executor executor,
ExecutionVertex vertex,
int attemptNumber,
long globalModVersion,
long startTimestamp,
Time rpcTimeout)
Creates a new Execution attempt.
|
ExecutionGraph(JobInformation jobInformation,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
RestartStrategy restartStrategy,
int maxPriorAttemptsHistoryLength,
FailoverStrategy.Factory failoverStrategyFactory,
SlotProvider slotProvider,
ClassLoader userClassLoader,
BlobWriter blobWriter,
Time allocationTimeout,
PartitionReleaseStrategy.Factory partitionReleaseStrategyFactory,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ScheduleMode scheduleMode) |
ExecutionJobVertex(ExecutionGraph graph,
JobVertex jobVertex,
int defaultParallelism,
int maxPriorAttemptsHistoryLength,
Time timeout,
long initialGlobalModVersion,
long createTimestamp) |
ExecutionVertex(ExecutionJobVertex jobVertex,
int subTaskIndex,
IntermediateResult[] producedDataSets,
Time timeout,
long initialGlobalModVersion,
long createTimestamp,
int maxPriorExecutionHistoryLength)
Creates an ExecutionVertex.
|
Constructor and Description |
---|
FailureRateRestartStrategy(int maxFailuresPerInterval,
Time failuresInterval,
Time delayInterval) |
FailureRateRestartStrategyFactory(int maxFailuresPerInterval,
Time failuresInterval,
Time delayInterval) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
TaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
CompletableFuture<Acknowledge> |
TaskManagerGateway.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
CompletableFuture<TaskBackPressureResponse> |
TaskManagerGateway.requestTaskBackPressure(ExecutionAttemptID executionAttemptID,
int requestId,
Time timeout)
Request the back pressure ratio for the given task.
|
CompletableFuture<Acknowledge> |
TaskManagerGateway.submitTask(TaskDeploymentDescriptor tdd,
Time timeout)
Submit a task to the task manager.
|
CompletableFuture<Acknowledge> |
TaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
Modifier and Type | Method and Description |
---|---|
Time |
JobMasterConfiguration.getRpcTimeout() |
Time |
JobMasterConfiguration.getSlotRequestTimeout() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
JobMaster.cancel(Time timeout) |
CompletableFuture<Acknowledge> |
JobMasterGateway.cancel(Time timeout)
Cancels the currently executed job.
|
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout) |
CompletableFuture<Collection<SlotOffer>> |
JobMaster.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout) |
CompletableFuture<Collection<SlotOffer>> |
JobMasterGateway.offerSlots(ResourceID taskManagerId,
Collection<SlotOffer> slots,
Time timeout)
Offers the given slots to the job manager.
|
CompletableFuture<RegistrationResponse> |
JobMaster.registerTaskManager(String taskManagerRpcAddress,
TaskManagerLocation taskManagerLocation,
Time timeout) |
CompletableFuture<RegistrationResponse> |
JobMasterGateway.registerTaskManager(String taskManagerRpcAddress,
TaskManagerLocation taskManagerLocation,
Time timeout)
Registers the task manager at the job manager.
|
CompletableFuture<ArchivedExecutionGraph> |
JobMaster.requestJob(Time timeout) |
CompletableFuture<ArchivedExecutionGraph> |
JobMasterGateway.requestJob(Time timeout)
Requests the
ArchivedExecutionGraph of the executed job. |
CompletableFuture<JobDetails> |
JobMaster.requestJobDetails(Time timeout) |
CompletableFuture<JobDetails> |
JobMasterGateway.requestJobDetails(Time timeout)
Request the details of the executed job.
|
CompletableFuture<JobStatus> |
JobMaster.requestJobStatus(Time timeout) |
CompletableFuture<JobStatus> |
JobMasterGateway.requestJobStatus(Time timeout)
Requests the current job status.
|
CompletableFuture<TaskBackPressureResponse> |
RpcTaskManagerGateway.requestTaskBackPressure(ExecutionAttemptID executionAttemptID,
int requestId,
Time timeout) |
CompletableFuture<Acknowledge> |
JobMaster.scheduleOrUpdateConsumers(ResultPartitionID partitionID,
Time timeout) |
CompletableFuture<Acknowledge> |
JobMasterGateway.scheduleOrUpdateConsumers(ResultPartitionID partitionID,
Time timeout)
Notifies the JobManager about available data for a produced partition.
|
CompletableFuture<String> |
JobMaster.stopWithSavepoint(String targetDirectory,
boolean advanceToEndOfEventTime,
Time timeout) |
CompletableFuture<String> |
JobMasterGateway.stopWithSavepoint(String targetDirectory,
boolean advanceToEndOfEventTime,
Time timeout)
Stops the job with a savepoint.
|
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.submitTask(TaskDeploymentDescriptor tdd,
Time timeout) |
CompletableFuture<String> |
JobMaster.triggerSavepoint(String targetDirectory,
boolean cancelJob,
Time timeout) |
CompletableFuture<String> |
JobMasterGateway.triggerSavepoint(String targetDirectory,
boolean cancelJob,
Time timeout)
Triggers taking a savepoint of the executed job.
|
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
Constructor and Description |
---|
JobMasterConfiguration(Time rpcTimeout,
Time slotRequestTimeout,
String tmpDirectory,
RetryingRegistrationConfiguration retryingRegistrationConfiguration,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<LogicalSlot> |
SlotProvider.allocateSlot(ScheduledUnit scheduledUnit,
SlotProfile slotProfile,
Time allocationTimeout)
Allocating slot with specific requirement.
|
CompletableFuture<LogicalSlot> |
SlotProvider.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit scheduledUnit,
SlotProfile slotProfile,
Time allocationTimeout)
Allocating slot with specific requirement.
|
CompletableFuture<LogicalSlot> |
SchedulerImpl.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit scheduledUnit,
SlotProfile slotProfile,
Time allocationTimeout) |
CompletableFuture<PhysicalSlot> |
SlotPoolImpl.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Time timeout) |
CompletableFuture<PhysicalSlot> |
SlotPool.requestNewAllocatedSlot(SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Time timeout)
Request the allocation of a new slot from the resource manager.
|
protected void |
SlotPoolImpl.scheduleRunAsync(Runnable runnable,
Time delay)
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
|
Constructor and Description |
---|
DefaultSlotPoolFactory(Clock clock,
Time rpcTimeout,
Time slotIdleTimeout,
Time batchSlotTimeout) |
SlotPoolImpl(JobID jobId,
Clock clock,
Time rpcTimeout,
Time idleSlotTimeout,
Time batchSlotTimeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<MetricDumpSerialization.MetricSerializationResult> |
MetricQueryService.queryMetrics(Time timeout) |
Modifier and Type | Method and Description |
---|---|
static void |
SystemResourcesMetricsInitializer.instantiateSystemMetrics(MetricGroup metricGroup,
Time probeInterval) |
Modifier and Type | Method and Description |
---|---|
static ProcessMetricGroup |
MetricUtils.instantiateProcessMetricGroup(MetricRegistry metricRegistry,
String hostname,
Optional<Time> systemResourceProbeInterval) |
static Tuple2<TaskManagerMetricGroup,MetricGroup> |
MetricUtils.instantiateTaskManagerMetricGroup(MetricRegistry metricRegistry,
String hostName,
ResourceID resourceID,
Optional<Time> systemResourceProbeInterval) |
Constructor and Description |
---|
SystemResourcesCounter(Time probeInterval) |
Modifier and Type | Method and Description |
---|---|
Time |
MiniClusterConfiguration.getRpcTimeout() |
Modifier and Type | Method and Description |
---|---|
Time |
ResourceManagerRuntimeServicesConfiguration.getJobTimeout() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<RegistrationResponse> |
ResourceManagerGateway.registerJobManager(JobMasterId jobMasterId,
ResourceID jobMasterResourceId,
String jobMasterAddress,
JobID jobId,
Time timeout)
Register a
JobMaster at the resource manager. |
CompletableFuture<RegistrationResponse> |
ResourceManager.registerJobManager(JobMasterId jobMasterId,
ResourceID jobManagerResourceId,
String jobManagerAddress,
JobID jobId,
Time timeout) |
CompletableFuture<RegistrationResponse> |
ResourceManagerGateway.registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration,
Time timeout)
Register a
TaskExecutor at the resource manager. |
CompletableFuture<RegistrationResponse> |
ResourceManager.registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration,
Time timeout) |
CompletableFuture<ResourceOverview> |
ResourceManagerGateway.requestResourceOverview(Time timeout)
Requests the resource overview.
|
CompletableFuture<ResourceOverview> |
ResourceManager.requestResourceOverview(Time timeout) |
CompletableFuture<Acknowledge> |
ResourceManagerGateway.requestSlot(JobMasterId jobMasterId,
SlotRequest slotRequest,
Time timeout)
Requests a slot from the resource manager.
|
CompletableFuture<Acknowledge> |
ResourceManager.requestSlot(JobMasterId jobMasterId,
SlotRequest slotRequest,
Time timeout) |
CompletableFuture<TransientBlobKey> |
ResourceManagerGateway.requestTaskManagerFileUpload(ResourceID taskManagerId,
FileType fileType,
Time timeout)
Request the file upload from the given
TaskExecutor to the cluster's BlobServer . |
CompletableFuture<TransientBlobKey> |
ResourceManager.requestTaskManagerFileUpload(ResourceID taskManagerId,
FileType fileType,
Time timeout) |
CompletableFuture<TaskManagerInfo> |
ResourceManagerGateway.requestTaskManagerInfo(ResourceID taskManagerId,
Time timeout)
Requests information about the given
TaskExecutor . |
CompletableFuture<TaskManagerInfo> |
ResourceManager.requestTaskManagerInfo(ResourceID resourceId,
Time timeout) |
CompletableFuture<Collection<TaskManagerInfo>> |
ResourceManagerGateway.requestTaskManagerInfo(Time timeout)
Requests information about the registered
TaskExecutor . |
CompletableFuture<Collection<TaskManagerInfo>> |
ResourceManager.requestTaskManagerInfo(Time timeout) |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
ResourceManagerGateway.requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
ResourceManager.requestTaskManagerMetricQueryServiceAddresses(Time timeout) |
CompletableFuture<Acknowledge> |
ResourceManagerGateway.sendSlotReport(ResourceID taskManagerResourceId,
InstanceID taskManagerRegistrationId,
SlotReport slotReport,
Time timeout)
Sends the given
SlotReport to the ResourceManager. |
CompletableFuture<Acknowledge> |
ResourceManager.sendSlotReport(ResourceID taskManagerResourceId,
InstanceID taskManagerRegistrationId,
SlotReport slotReport,
Time timeout) |
Constructor and Description |
---|
JobLeaderIdService(HighAvailabilityServices highAvailabilityServices,
ScheduledExecutor scheduledExecutor,
Time jobTimeout) |
ResourceManagerRuntimeServicesConfiguration(Time jobTimeout,
SlotManagerConfiguration slotManagerConfiguration) |
StandaloneResourceManager(RpcService rpcService,
String resourceManagerEndpointId,
ResourceID resourceId,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
SlotManager slotManager,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time startupPeriodTime) |
Modifier and Type | Method and Description |
---|---|
Time |
SlotManagerConfiguration.getSlotRequestTimeout() |
Time |
SlotManagerConfiguration.getTaskManagerRequestTimeout() |
Time |
SlotManagerConfiguration.getTaskManagerTimeout() |
Constructor and Description |
---|
SlotManagerConfiguration(Time taskManagerRequestTimeout,
Time slotRequestTimeout,
Time taskManagerTimeout,
boolean waitResultConsumedBeforeRelease,
boolean evenlySpreadOutSlots) |
SlotManagerImpl(SlotMatchingStrategy slotMatchingStrategy,
ScheduledExecutor scheduledExecutor,
Time taskManagerRequestTimeout,
Time slotRequestTimeout,
Time taskManagerTimeout,
boolean waitResultConsumedBeforeRelease) |
Modifier and Type | Method and Description |
---|---|
void |
RestClient.shutdown(Time timeout) |
Modifier and Type | Field and Description |
---|---|
protected Time |
LeaderRetrievalHandler.timeout |
Modifier and Type | Method and Description |
---|---|
Time |
RestHandlerConfiguration.getTimeout() |
Constructor and Description |
---|
AbstractHandler(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
UntypedResponseMessageHeaders<R,M> untypedResponseMessageHeaders) |
AbstractRestHandler(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<R,P,M> messageHeaders) |
LeaderRetrievalHandler(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
RestHandlerConfiguration(long refreshInterval,
int maxCheckpointStatisticCacheEntries,
Time timeout,
File webUiDir,
boolean webSubmitEnabled) |
Constructor and Description |
---|
StatusHandler(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,AsynchronousOperationResult<V>,M> messageHeaders) |
TriggerHandler(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<B,TriggerResponse,M> messageHeaders) |
Constructor and Description |
---|
RescalingStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
RescalingTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
Constructor and Description |
---|
SavepointDisposalStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointDisposalTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
StopWithSavepointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
Constructor and Description |
---|
DefaultExecutionGraphCache(Time timeout,
Time timeToLive) |
Constructor and Description |
---|
StaticFileServerHandler(GatewayRetriever<? extends T> retriever,
Time timeout,
File rootPath) |
Constructor and Description |
---|
MetricFetcherImpl(GatewayRetriever<T> retriever,
MetricQueryServiceRetriever queryServiceRetriever,
Executor executor,
Time timeout,
long updateInterval) |
Modifier and Type | Field and Description |
---|---|
static Time |
RpcUtils.INF_TIMEOUT
HACK: Set to 21474835 seconds, Akka's maximum delay (Akka 2.4.20).
|
Modifier and Type | Method and Description |
---|---|
protected <V> CompletableFuture<V> |
RpcEndpoint.callAsync(Callable<V> callable,
Time timeout)
Execute the callable in the main thread of the underlying RPC service, returning a future for
the result of the callable.
|
<V> CompletableFuture<V> |
MainThreadExecutable.callAsync(Callable<V> callable,
Time callTimeout)
Execute the callable in the main thread of the underlying RPC endpoint and return a future for
the callable result.
|
<V> CompletableFuture<V> |
FencedMainThreadExecutable.callAsyncWithoutFencing(Callable<V> callable,
Time timeout)
Run the given callable in the main thread without attaching a fencing token.
|
protected <V> CompletableFuture<V> |
FencedRpcEndpoint.callAsyncWithoutFencing(Callable<V> callable,
Time timeout)
Run the given callable in the main thread of the RpcEndpoint without checking the fencing
token.
|
protected void |
RpcEndpoint.scheduleRunAsync(Runnable runnable,
Time delay)
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
|
static void |
RpcUtils.terminateRpcEndpoint(RpcEndpoint rpcEndpoint,
Time timeout)
Shuts the given
RpcEndpoint down and awaits its termination. |
static void |
RpcUtils.terminateRpcService(RpcService rpcService,
Time timeout)
Shuts the given rpc service down and waits for its termination.
|
static void |
RpcUtils.terminateRpcServices(Time timeout,
RpcService... rpcServices)
Shuts the given rpc services down and waits for their termination.
|
Modifier and Type | Method and Description |
---|---|
Time |
AkkaRpcServiceConfiguration.getTimeout() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<?> |
FencedAkkaInvocationHandler.ask(Object message,
Time timeout) |
<V> CompletableFuture<V> |
FencedAkkaInvocationHandler.callAsyncWithoutFencing(Callable<V> callable,
Time timeout) |
Constructor and Description |
---|
AkkaRpcServiceConfiguration(Configuration configuration,
Time timeout,
long maximumFramesize) |
FencedAkkaInvocationHandler(String address,
String hostname,
akka.actor.ActorRef rpcEndpoint,
Time timeout,
long maximumFramesize,
CompletableFuture<Void> terminationFuture,
java.util.function.Supplier<F> fencingTokenSupplier) |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
DefaultSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker) |
SchedulerNG |
SchedulerNGFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker) |
SchedulerNG |
LegacySchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker) |
Constructor and Description |
---|
DefaultScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
org.apache.flink.runtime.scheduler.ExecutionVertexOperations executionVertexOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory) |
LegacyScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
RestartStrategyFactory restartStrategyFactory,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker) |
SchedulerBase(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
RestartStrategyFactory restartStrategyFactory,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionVertexVersioner executionVertexVersioner,
boolean legacyScheduling) |
Modifier and Type | Method and Description |
---|---|
Time |
TaskManagerConfiguration.getInitialRegistrationPause() |
Time |
TaskManagerConfiguration.getMaxRegistrationDuration() |
Time |
TaskManagerConfiguration.getMaxRegistrationPause() |
Time |
TaskManagerConfiguration.getRefusedRegistrationPause() |
Time |
TaskManagerConfiguration.getTimeout() |
Modifier and Type | Method and Description |
---|---|
Optional<Time> |
TaskManagerServicesConfiguration.getSystemResourceMetricsProbingInterval() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
TaskExecutorGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
CompletableFuture<Acknowledge> |
TaskExecutor.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout) |
CompletableFuture<TransientBlobKey> |
TaskExecutorGateway.requestFileUpload(FileType fileType,
Time timeout)
Requests the file upload of the specified type to the cluster's
BlobServer . |
CompletableFuture<TransientBlobKey> |
TaskExecutor.requestFileUpload(FileType fileType,
Time timeout) |
CompletableFuture<SerializableOptional<String>> |
TaskExecutorGateway.requestMetricQueryServiceAddress(Time timeout)
Returns the gateway of Metric Query Service on the TaskManager.
|
CompletableFuture<SerializableOptional<String>> |
TaskExecutor.requestMetricQueryServiceAddress(Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager.
|
CompletableFuture<Acknowledge> |
TaskExecutor.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<TaskBackPressureResponse> |
TaskExecutorGateway.requestTaskBackPressure(ExecutionAttemptID executionAttemptId,
int requestId,
Time timeout) |
CompletableFuture<TaskBackPressureResponse> |
TaskExecutor.requestTaskBackPressure(ExecutionAttemptID executionAttemptId,
int requestId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.submitTask(TaskDeploymentDescriptor tdd,
JobMasterId jobMasterId,
Time timeout)
Submit a
Task to the TaskExecutor . |
CompletableFuture<Acknowledge> |
TaskExecutor.submitTask(TaskDeploymentDescriptor tdd,
JobMasterId jobMasterId,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
CompletableFuture<Acknowledge> |
TaskExecutor.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
Constructor and Description |
---|
TaskManagerConfiguration(int numberSlots,
ResourceProfile defaultSlotResourceProfile,
ResourceProfile totalResourceProfile,
String[] tmpDirectories,
Time timeout,
Time maxRegistrationDuration,
Time initialRegistrationPause,
Time maxRegistrationPause,
Time refusedRegistrationPause,
Configuration configuration,
boolean exitJvmOnOutOfMemory,
FlinkUserCodeClassLoaders.ResolveOrder classLoaderResolveOrder,
String[] alwaysParentFirstLoaderPatterns,
String taskManagerLogPath,
String taskManagerStdoutPath,
RetryingRegistrationConfiguration retryingRegistrationConfiguration) |
Constructor and Description |
---|
TaskManagerServicesConfiguration(Configuration configuration,
ResourceID resourceID,
InetAddress taskManagerAddress,
boolean localCommunicationOnly,
String[] tmpDirPaths,
String[] localRecoveryStateRootDirectories,
boolean localRecoveryEnabled,
QueryableStateConfiguration queryableStateConfig,
int numberOfSlots,
int pageSize,
TaskExecutorResourceSpec taskExecutorResourceSpec,
long timerServiceShutdownTimeout,
RetryingRegistrationConfiguration retryingRegistrationConfiguration,
Optional<Time> systemResourceMetricsProbingInterval,
int numIoThreads) |
Constructor and Description |
---|
RpcInputSplitProvider(JobMasterGateway jobMasterGateway,
JobVertexID jobVertexID,
ExecutionAttemptID executionAttemptID,
Time timeout) |
RpcResultPartitionConsumableNotifier(JobMasterGateway jobMasterGateway,
Executor executor,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
boolean |
TaskSlotTableImpl.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
Time slotTimeout) |
boolean |
TaskSlotTable.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
Time slotTimeout)
Allocate the slot with the given index for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Time slotTimeout) |
boolean |
TaskSlotTable.allocateSlot(int index,
JobID jobId,
AllocationID allocationId,
Time slotTimeout)
Allocate the slot with the given index for the given job and allocation id.
|
boolean |
TaskSlotTableImpl.markSlotInactive(AllocationID allocationId,
Time slotTimeout) |
boolean |
TaskSlotTable.markSlotInactive(AllocationID allocationId,
Time slotTimeout)
Marks the slot under the given allocation id as inactive.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
RestfulGateway.cancelJob(JobID jobId,
Time timeout)
Cancel the given job.
|
default CompletableFuture<Acknowledge> |
RestfulGateway.disposeSavepoint(String savepointPath,
Time timeout)
Dispose the given savepoint.
|
static WebMonitorExtension |
WebMonitorUtils.loadWebSubmissionExtension(GatewayRetriever<? extends DispatcherGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
CompletableFuture<String> localAddressFuture,
Path uploadDir,
Executor executor,
Configuration configuration)
Loads the
WebMonitorExtension which enables web submission. |
CompletableFuture<ClusterOverview> |
RestfulGateway.requestClusterOverview(Time timeout)
Requests the cluster status overview.
|
CompletableFuture<ArchivedExecutionGraph> |
RestfulGateway.requestJob(JobID jobId,
Time timeout)
Requests the
ArchivedExecutionGraph for the given jobId. |
CompletableFuture<JobResult> |
RestfulGateway.requestJobResult(JobID jobId,
Time timeout)
Requests the
JobResult of a job specified by the given jobId. |
default CompletableFuture<JobStatus> |
RestfulGateway.requestJobStatus(JobID jobId,
Time timeout)
Request the
JobStatus of the given job. |
CompletableFuture<Collection<String>> |
RestfulGateway.requestMetricQueryServiceAddresses(Time timeout)
Requests the addresses of the
MetricQueryService to query. |
CompletableFuture<MultipleJobsDetails> |
RestfulGateway.requestMultipleJobDetails(Time timeout)
Requests job details currently being executed on the Flink cluster.
|
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
RestfulGateway.requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the addresses for the TaskManagers'
MetricQueryService to query. |
default CompletableFuture<String> |
RestfulGateway.stopWithSavepoint(JobID jobId,
String targetDirectory,
boolean advanceToEndOfEventTime,
Time timeout)
Stops the job with a savepoint.
|
default CompletableFuture<String> |
RestfulGateway.triggerSavepoint(JobID jobId,
String targetDirectory,
boolean cancelJob,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target.
|
static <T extends RestfulGateway> |
WebMonitorUtils.tryLoadWebContent(GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
File tmpDir)
Checks whether the flink-runtime-web dependency is available and if so returns a
StaticFileServerHandler which can serve the static file contents.
|
Constructor and Description |
---|
WebSubmissionExtension(Configuration configuration,
GatewayRetriever<? extends DispatcherGateway> leaderRetriever,
Map<String,String> responseHeaders,
CompletableFuture<String> localAddressFuture,
Path jarDir,
Executor executor,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<MetricDumpSerialization.MetricSerializationResult> |
MetricQueryServiceGateway.queryMetrics(Time timeout) |
Constructor and Description |
---|
RpcGatewayRetriever(RpcService rpcService,
Class<T> gatewayType,
java.util.function.Function<UUID,F> fencingTokenMapper,
int retries,
Time retryDelay) |
Modifier and Type | Field and Description |
---|---|
static Time |
FlinkKafkaProducer.DEFAULT_KAFKA_TRANSACTION_TIMEOUT
Default value for kafka transaction timeout.
|
static Time |
FlinkKafkaProducer011.DEFAULT_KAFKA_TRANSACTION_TIMEOUT
Default value for kafka transaction timeout.
|
Modifier and Type | Method and Description |
---|---|
void |
TableConfig.setIdleStateRetentionTime(Time minTime,
Time maxTime)
Specifies a minimum and a maximum time interval for how long idle state, i.e., state which
was not updated, will be retained.
|
StreamQueryConfig |
StreamQueryConfig.withIdleStateRetentionTime(Time minTime,
Time maxTime)
Deprecated.
Specifies a minimum and a maximum time interval for how long idle state, i.e., state which
was not updated, will be retained.
|
Modifier and Type | Field and Description |
---|---|
static Time |
TestBaseUtils.DEFAULT_HTTP_TIMEOUT |
Modifier and Type | Method and Description |
---|---|
static String |
TestBaseUtils.getFromHTTP(String url,
Time timeout) |
MiniClusterResourceConfiguration.Builder |
MiniClusterResourceConfiguration.Builder.setShutdownTimeout(Time shutdownTimeout) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.