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 |
---|---|
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. |
Constructor and Description |
---|
DefaultQuarantineHandler(Time timeout,
int exitCode,
org.slf4j.Logger log) |
Modifier and Type | Method and Description |
---|---|
static List<MasterState> |
MasterHooks.triggerMasterHooks(Collection<MasterTriggerRestoreHook<?>> hooks,
long checkpointId,
long timestamp,
Executor executor,
Time timeout)
Triggers all given master hooks and returns state objects for each hook that
produced a state.
|
Modifier and Type | Method and Description |
---|---|
static CompletableFuture<InetSocketAddress> |
JobClient.retrieveBlobServerAddress(JobManagerGateway jobManagerGateway,
Time timeout)
Utility method to retrieve the BlobServer address from the given JobManager gateway.
|
static ClassLoader |
JobClient.retrieveClassLoader(JobID jobID,
JobManagerGateway jobManager,
Configuration config,
HighAvailabilityServices highAvailabilityServices,
Time timeout)
Reconstructs the class loader by first requesting information about it at the JobManager
and then downloading missing jar files.
|
static void |
JobClient.submitJobDetached(JobManagerGateway jobManagerGateway,
Configuration config,
JobGraph jobGraph,
Time timeout,
ClassLoader classLoader)
Submits a job in detached mode.
|
Modifier and Type | Method and Description |
---|---|
static WebMonitor |
BootstrapTools.startWebMonitorIfConfigured(Configuration config,
HighAvailabilityServices highAvailabilityServices,
LeaderGatewayRetriever<JobManagerGateway> jobManagerRetriever,
MetricQueryServiceRetriever queryServiceRetriever,
Time timeout,
ScheduledExecutor scheduledExecutor,
org.slf4j.Logger logger)
Starts the web frontend.
|
Modifier and Type | Method and Description |
---|---|
static Time |
FutureUtils.toTime(scala.concurrent.duration.FiniteDuration finiteDuration)
Converts
FiniteDuration into Flink time. |
Modifier and Type | Method and Description |
---|---|
static <T> CompletableFuture<T> |
FutureUtils.retrySuccesfulWithDelay(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 scala.concurrent.duration.FiniteDuration |
FutureUtils.toFiniteDuration(Time time)
Converts Flink time into a
FiniteDuration . |
Constructor and Description |
---|
FileArchivedExecutionGraphStore(File rootDir,
Time expirationTime,
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 |
---|---|
CompletableFuture<Execution> |
Execution.allocateAndAssignSlotForExecution(SlotProvider slotProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Time allocationTimeout)
Allocates and assigns a slot obtained from the slot provider to the execution.
|
Collection<CompletableFuture<Execution>> |
ExecutionJobVertex.allocateResourcesForAll(SlotProvider resourceProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Time allocationTimeout)
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
|
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)
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,
int parallelismForAutoMax,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log)
Deprecated.
|
CompletableFuture<StackTraceSampleResponse> |
Execution.requestStackTraceSample(int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout)
Request a stack trace sample 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,
FailoverStrategy.Factory failoverStrategyFactory,
SlotProvider slotProvider,
ClassLoader userClassLoader,
BlobWriter blobWriter,
Time allocationTimeout) |
ExecutionJobVertex(ExecutionGraph graph,
JobVertex jobVertex,
int defaultParallelism,
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<LogicalSlot> |
Scheduler.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
boolean allowQueued,
SlotProfile slotProfile,
Time allocationTimeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
CompletableFuture<StackTrace> |
ActorTaskManagerGateway.requestStackTrace(Time timeout) |
CompletableFuture<StackTrace> |
TaskManagerGateway.requestStackTrace(Time timeout)
Request the stack trace from the task manager.
|
CompletableFuture<StackTraceSampleResponse> |
ActorTaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
TaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout)
Request a stack trace sample from the given task.
|
CompletableFuture<TransientBlobKey> |
ActorTaskManagerGateway.requestTaskManagerLog(Time timeout) |
CompletableFuture<TransientBlobKey> |
TaskManagerGateway.requestTaskManagerLog(Time timeout)
Request the task manager log from the task manager.
|
CompletableFuture<TransientBlobKey> |
ActorTaskManagerGateway.requestTaskManagerStdout(Time timeout) |
CompletableFuture<TransientBlobKey> |
TaskManagerGateway.requestTaskManagerStdout(Time timeout)
Request the task manager stdout from the task manager.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.submitTask(TaskDeploymentDescriptor tdd,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskManagerGateway.submitTask(TaskDeploymentDescriptor tdd,
Time timeout)
Submit a task to the task manager.
|
CompletableFuture<Acknowledge> |
ActorTaskManagerGateway.updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout) |
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> |
JobManagerGateway.cancelJob(JobID jobId,
Time timeout)
Cancels the given job.
|
CompletableFuture<String> |
JobManagerGateway.cancelJobWithSavepoint(JobID jobId,
String savepointPath,
Time timeout)
Cancels the given job after taking a savepoint and returning its path.
|
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<Integer> |
JobManagerGateway.requestBlobServerPort(Time timeout)
Requests the BlobServer port.
|
CompletableFuture<Optional<org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps>> |
JobManagerGateway.requestClassloadingProps(JobID jobId,
Time timeout)
Requests the class loading properties for the given JobID.
|
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<JobIdsWithStatusOverview> |
JobManagerGateway.requestJobsOverview(Time timeout)
Requests the job overview from the JobManager.
|
CompletableFuture<JobStatus> |
JobMaster.requestJobStatus(Time timeout) |
CompletableFuture<JobStatus> |
JobMasterGateway.requestJobStatus(Time timeout)
Requests the current job status.
|
CompletableFuture<StackTrace> |
RpcTaskManagerGateway.requestStackTrace(Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
RpcTaskManagerGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<Optional<Instance>> |
JobManagerGateway.requestTaskManagerInstance(ResourceID resourceId,
Time timeout)
Requests the TaskManager instance registered under the given instanceId from the JobManager.
|
CompletableFuture<Collection<Instance>> |
JobManagerGateway.requestTaskManagerInstances(Time timeout)
Requests all currently registered TaskManager instances from the JobManager.
|
CompletableFuture<TransientBlobKey> |
RpcTaskManagerGateway.requestTaskManagerLog(Time timeout) |
CompletableFuture<TransientBlobKey> |
RpcTaskManagerGateway.requestTaskManagerStdout(Time timeout) |
CompletableFuture<Acknowledge> |
JobMaster.rescaleJob(int newParallelism,
RescalingBehaviour rescalingBehaviour,
Time timeout) |
CompletableFuture<Acknowledge> |
JobMasterGateway.rescaleJob(int newParallelism,
RescalingBehaviour rescalingBehaviour,
Time timeout)
Triggers rescaling of the executed job.
|
CompletableFuture<Acknowledge> |
JobMaster.rescaleOperators(Collection<JobVertexID> operators,
int newParallelism,
RescalingBehaviour rescalingBehaviour,
Time timeout) |
CompletableFuture<Acknowledge> |
JobMasterGateway.rescaleOperators(Collection<JobVertexID> operators,
int newParallelism,
RescalingBehaviour rescalingBehaviour,
Time timeout)
Triggers rescaling of the given set of operators.
|
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<Acknowledge> |
JobMaster.start(JobMasterId newJobMasterId,
Time timeout)
Start the rpc service and begin to run the job.
|
CompletableFuture<Acknowledge> |
JobMaster.stop(Time timeout) |
CompletableFuture<Acknowledge> |
JobMasterGateway.stop(Time timeout)
Cancel the currently executed job.
|
CompletableFuture<Acknowledge> |
JobManagerGateway.stopJob(JobID jobId,
Time timeout)
Stops the given job.
|
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout) |
CompletableFuture<Acknowledge> |
JobManagerGateway.submitJob(JobGraph jobGraph,
ListeningBehaviour listeningBehaviour,
Time timeout)
Submits a job to the JobManager.
|
CompletableFuture<Acknowledge> |
RpcTaskManagerGateway.submitTask(TaskDeploymentDescriptor tdd,
Time timeout) |
CompletableFuture<Acknowledge> |
JobMaster.suspend(Exception cause,
Time timeout)
Suspending job, all the running tasks will be cancelled, and communication with other components
will be disposed.
|
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,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<LogicalSlot> |
SlotProvider.allocateSlot(ScheduledUnit task,
boolean allowQueued,
SlotProfile slotProfile,
Time timeout)
Allocating slot with specific requirement.
|
CompletableFuture<LogicalSlot> |
SlotProvider.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
boolean allowQueued,
SlotProfile slotProfile,
Time timeout)
Allocating slot with specific requirement.
|
CompletableFuture<LogicalSlot> |
SlotPoolGateway.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit scheduledUnit,
SlotProfile slotProfile,
boolean allowQueuedScheduling,
Time timeout)
Requests to allocate a slot for the given
ScheduledUnit . |
CompletableFuture<LogicalSlot> |
SlotPool.allocateSlot(SlotRequestId slotRequestId,
ScheduledUnit task,
SlotProfile slotProfile,
boolean allowQueuedScheduling,
Time allocationTimeout) |
Constructor and Description |
---|
DefaultSlotPoolFactory(RpcService rpcService,
SchedulingStrategy schedulingStrategy,
Clock clock,
Time rpcTimeout,
Time slotIdleTimeout) |
SlotPool(RpcService rpcService,
JobID jobId,
SchedulingStrategy schedulingStrategy,
Clock clock,
Time rpcTimeout,
Time idleSlotTimeout) |
Modifier and Type | Method and Description |
---|---|
Time |
MiniClusterConfiguration.getRpcTimeout() |
Modifier and Type | Method and Description |
---|---|
protected RpcService |
MiniCluster.createRpcService(Configuration configuration,
Time askTimeout,
boolean remoteEnabled,
String bindAddress)
Factory method to instantiate the RPC service.
|
Modifier and Type | Method and Description |
---|---|
Time |
ResourceManagerConfiguration.getHeartbeatInterval() |
Time |
ResourceManagerRuntimeServicesConfiguration.getJobTimeout() |
Time |
ResourceManagerConfiguration.getTimeout() |
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(String taskExecutorAddress,
ResourceID resourceId,
int dataPort,
HardwareDescription hardwareDescription,
Time timeout)
Register a
TaskExecutor at the resource manager. |
CompletableFuture<RegistrationResponse> |
ResourceManager.registerTaskExecutor(String taskExecutorAddress,
ResourceID taskExecutorResourceId,
int dataPort,
HardwareDescription hardwareDescription,
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.requestTaskManagerMetricQueryServicePaths(Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
ResourceManager.requestTaskManagerMetricQueryServicePaths(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) |
ResourceManagerConfiguration(Time timeout,
Time heartbeatInterval) |
ResourceManagerRuntimeServicesConfiguration(Time jobTimeout,
SlotManagerConfiguration slotManagerConfiguration) |
Modifier and Type | Method and Description |
---|---|
Time |
SlotManagerConfiguration.getSlotRequestTimeout() |
Time |
SlotManagerConfiguration.getTaskManagerRequestTimeout() |
Time |
SlotManagerConfiguration.getTaskManagerTimeout() |
Constructor and Description |
---|
SlotManager(ScheduledExecutor scheduledExecutor,
Time taskManagerRequestTimeout,
Time slotRequestTimeout,
Time taskManagerTimeout) |
SlotManagerConfiguration(Time taskManagerRequestTimeout,
Time slotRequestTimeout,
Time taskManagerTimeout) |
Modifier and Type | Method and Description |
---|---|
void |
RestClient.shutdown(Time timeout) |
Modifier and Type | Field and Description |
---|---|
protected Time |
RedirectHandler.timeout |
Modifier and Type | Method and Description |
---|---|
Time |
RestHandlerConfiguration.getTimeout() |
Constructor and Description |
---|
AbstractHandler(CompletableFuture<String> localAddressFuture,
GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
UntypedResponseMessageHeaders<R,M> untypedResponseMessageHeaders) |
AbstractRestHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<R,P,M> messageHeaders) |
LegacyRestHandlerAdapter(CompletableFuture<String> localRestAddress,
GatewayRetriever<T> leaderRetriever,
Time timeout,
Map<String,String> headers,
MessageHeaders<EmptyRequestBody,R,M> messageHeaders,
LegacyRestHandler<T,R,M> legacyRestHandler) |
RedirectHandler(CompletableFuture<String> localAddressFuture,
GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
RestHandlerConfiguration(long refreshInterval,
int maxCheckpointStatisticCacheEntries,
Time timeout,
File webUiDir) |
Constructor and Description |
---|
StatusHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,AsynchronousOperationResult<V>,M> messageHeaders) |
TriggerHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends T> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<B,TriggerResponse,M> messageHeaders) |
Constructor and Description |
---|
RescalingStatusHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
RescalingTriggerHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
Constructor and Description |
---|
SavepointDisposalStatusHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointDisposalTriggerHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointStatusHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
SavepointTriggerHandler(CompletableFuture<String> localRestAddress,
GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders) |
Constructor and Description |
---|
ClusterOverviewHandler(Executor executor,
Time timeout) |
CurrentJobIdsHandler(Executor executor,
Time timeout) |
ExecutionGraphCache(Time timeout,
Time timeToLive) |
JobCancellationHandler(Executor executor,
Time timeout) |
JobsOverviewHandler(Executor executor,
Time timeout) |
JobStoppingHandler(Executor executor,
Time timeout) |
TaskManagerLogHandler(GatewayRetriever<JobManagerGateway> retriever,
Executor executor,
CompletableFuture<String> localJobManagerAddressPromise,
Time timeout,
TaskManagerLogHandler.FileMode fileMode,
Configuration config) |
TaskManagersHandler(Executor executor,
Time timeout,
MetricFetcher fetcher) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<StackTraceSample> |
StackTraceSampleCoordinator.triggerStackTraceSample(ExecutionVertex[] tasksToSample,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth)
Triggers a stack trace sample to all tasks.
|
Constructor and Description |
---|
BackPressureStatsTrackerImpl(StackTraceSampleCoordinator coordinator,
int cleanUpInterval,
int numSamples,
int backPressureStatsRefreshInterval,
Time delayBetweenSamples)
Creates a back pressure statistics tracker.
|
Constructor and Description |
---|
StaticFileServerHandler(GatewayRetriever<? extends T> retriever,
CompletableFuture<String> localJobManagerAddressFuture,
Time timeout,
File rootPath) |
Constructor and Description |
---|
MetricFetcher(GatewayRetriever<T> retriever,
MetricQueryServiceRetriever queryServiceRetriever,
Executor executor,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
static CompletableFuture<Optional<String>> |
HandlerRedirectUtils.getRedirectAddress(String localRestAddress,
RestfulGateway restfulGateway,
Time timeout) |
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 |
---|---|
CompletableFuture<?> |
FencedAkkaInvocationHandler.ask(Object message,
Time timeout) |
<V> CompletableFuture<V> |
FencedAkkaInvocationHandler.callAsyncWithoutFencing(Callable<V> callable,
Time timeout) |
Constructor and Description |
---|
AkkaRpcService(akka.actor.ActorSystem actorSystem,
Time timeout) |
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 |
---|---|
Time |
TaskManagerConfiguration.getInitialRegistrationPause() |
Time |
TaskManagerConfiguration.getMaxRegistrationDuration() |
Time |
TaskManagerConfiguration.getMaxRegistrationPause() |
Time |
TaskManagerConfiguration.getRefusedRegistrationPause() |
Time |
TaskManagerConfiguration.getTimeout() |
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<Acknowledge> |
TaskExecutorGateway.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager.
|
CompletableFuture<Acknowledge> |
TaskExecutor.requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
TaskExecutorGateway.requestStackTraceSample(ExecutionAttemptID executionAttemptId,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<StackTraceSampleResponse> |
TaskExecutor.requestStackTraceSample(ExecutionAttemptID executionAttemptId,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout) |
CompletableFuture<Acknowledge> |
TaskExecutorGateway.stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.stopTask(ExecutionAttemptID executionAttemptID,
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,
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) |
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 |
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 |
TaskSlotTable.markSlotInactive(AllocationID allocationId,
Time slotTimeout)
Marks the slot under the given allocation id as inactive.
|
Constructor and Description |
---|
ActorGatewayKvStateLocationOracle(ActorGateway jobManagerActorGateway,
Time timeout) |
Modifier and Type | Method and Description |
---|---|
static InetAddress |
LeaderRetrievalUtils.findConnectingAddress(LeaderRetrievalService leaderRetrievalService,
Time timeout) |
static LeaderConnectionInfo |
LeaderRetrievalUtils.retrieveLeaderConnectionInfo(LeaderRetrievalService leaderRetrievalService,
Time timeout)
Retrieves the leader akka url and the current leader session ID.
|
Modifier and Type | Field and Description |
---|---|
static Time |
WebRuntimeMonitor.DEFAULT_REQUEST_TIMEOUT
By default, all requests to the JobManager have a timeout of 10 seconds.
|
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,
CompletableFuture<String> restAddressFuture,
Time timeout,
Map<String,String> responseHeaders,
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<? extends AccessExecutionGraph> |
RestfulGateway.requestJob(JobID jobId,
Time timeout)
Requests the
AccessExecutionGraph 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.requestMetricQueryServicePaths(Time timeout)
Requests the paths for the
MetricQueryService to query. |
CompletableFuture<MultipleJobsDetails> |
RestfulGateway.requestMultipleJobDetails(Time timeout)
Requests job details currently being executed on the Flink cluster.
|
CompletableFuture<String> |
RestfulGateway.requestRestAddress(Time timeout)
Requests the REST address of this
RpcEndpoint . |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
RestfulGateway.requestTaskManagerMetricQueryServicePaths(Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
default CompletableFuture<Acknowledge> |
RestfulGateway.rescaleJob(JobID jobId,
int newParallelism,
RescalingBehaviour rescalingBehaviour,
Time timeout)
Trigger rescaling of the given job.
|
static WebMonitor |
WebMonitorUtils.startWebRuntimeMonitor(Configuration config,
HighAvailabilityServices highAvailabilityServices,
LeaderGatewayRetriever<JobManagerGateway> jobManagerRetriever,
MetricQueryServiceRetriever queryServiceRetriever,
Time timeout,
ScheduledExecutor scheduledExecutor)
Starts the web runtime monitor.
|
CompletableFuture<Acknowledge> |
RestfulGateway.stopJob(JobID jobId,
Time timeout)
Stop the given job.
|
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,
CompletableFuture<String> restAddressFuture,
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 |
---|
RuntimeMonitorHandler(WebMonitorConfig cfg,
RequestHandler handler,
GatewayRetriever<JobManagerGateway> retriever,
CompletableFuture<String> localJobManagerAddressFuture,
Time timeout) |
WebRuntimeMonitor(Configuration config,
LeaderRetrievalService leaderRetrievalService,
LeaderGatewayRetriever<JobManagerGateway> jobManagerRetriever,
MetricQueryServiceRetriever queryServiceRetriever,
Time timeout,
ScheduledExecutor scheduledExecutor) |
WebSubmissionExtension(Configuration configuration,
CompletableFuture<String> restAddressFuture,
GatewayRetriever<? extends DispatcherGateway> leaderRetriever,
Map<String,String> responseHeaders,
Path jarDir,
Executor executor,
Time timeout) |
Constructor and Description |
---|
JarRunHandler(Executor executor,
File jarDirectory,
Time timeout,
Configuration clientConfig) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<MetricDumpSerialization.MetricSerializationResult> |
MetricQueryServiceGateway.queryMetrics(Time timeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<MetricDumpSerialization.MetricSerializationResult> |
AkkaQueryServiceGateway.queryMetrics(Time timeout) |
Constructor and Description |
---|
AkkaJobManagerRetriever(akka.actor.ActorSystem actorSystem,
Time timeout,
int retries,
Time retryDelay) |
AkkaQueryServiceRetriever(akka.actor.ActorSystem actorSystem,
Time lookupTimeout) |
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 |
FlinkKafkaProducer011.DEFAULT_KAFKA_TRANSACTION_TIMEOUT
Default value for kafka transaction timeout.
|
Modifier and Type | Field and Description |
---|---|
static Time |
TestBaseUtils.DEFAULT_HTTP_TIMEOUT |
Modifier and Type | Method and Description |
---|---|
Time |
MiniClusterResource.MiniClusterResourceConfiguration.getShutdownTimeout() |
Modifier and Type | Method and Description |
---|---|
static String |
TestBaseUtils.getFromHTTP(String url,
Time timeout) |
Constructor and Description |
---|
MiniClusterResourceConfiguration(Configuration configuration,
int numberTaskManagers,
int numberSlotsPerTaskManager,
Time shutdownTimeout) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.