Uses of Interface
org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategy
-
-
Uses of RestartBackoffTimeStrategy in org.apache.flink.runtime.executiongraph.failover
Classes in org.apache.flink.runtime.executiongraph.failover that implement RestartBackoffTimeStrategy Modifier and Type Class Description class
ExponentialDelayRestartBackoffTimeStrategy
Restart strategy which tries to restart indefinitely number of times with an exponential backoff time in between.class
FailureRateRestartBackoffTimeStrategy
Restart strategy which can restart when failure rate is not exceeded.class
FixedDelayRestartBackoffTimeStrategy
Restart strategy which tries to restart a fixed number of times with a fixed backoff time in between.class
NoRestartBackoffTimeStrategy
Restart strategy which does not restart tasks when tasks fail.Methods in org.apache.flink.runtime.executiongraph.failover that return RestartBackoffTimeStrategy Modifier and Type Method Description RestartBackoffTimeStrategy
ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory. create()
RestartBackoffTimeStrategy
FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory. create()
RestartBackoffTimeStrategy
FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory. create()
RestartBackoffTimeStrategy
NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory. create()
RestartBackoffTimeStrategy
RestartBackoffTimeStrategy.Factory. create()
Instantiates theRestartBackoffTimeStrategy
.Constructors in org.apache.flink.runtime.executiongraph.failover with parameters of type RestartBackoffTimeStrategy Constructor Description ExecutionFailureHandler(org.apache.flink.configuration.Configuration jobMasterConfig, SchedulingTopology schedulingTopology, FailoverStrategy failoverStrategy, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, org.apache.flink.core.failure.FailureEnricher.Context taskFailureCtx, org.apache.flink.core.failure.FailureEnricher.Context globalFailureCtx, org.apache.flink.metrics.MetricGroup metricGroup)
Creates the handler to deal with task failures. -
Uses of RestartBackoffTimeStrategy in org.apache.flink.runtime.scheduler
Constructors in org.apache.flink.runtime.scheduler with parameters of type RestartBackoffTimeStrategy Constructor Description DefaultScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, Consumer<org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor> startUpAction, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Duration rpcTimeout, VertexParallelismStore vertexParallelismStore, ExecutionDeployer.Factory executionDeployerFactory, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-
Uses of RestartBackoffTimeStrategy in org.apache.flink.runtime.scheduler.adaptive
Constructors in org.apache.flink.runtime.scheduler.adaptive with parameters of type RestartBackoffTimeStrategy Constructor Description AdaptiveScheduler(AdaptiveScheduler.Settings settings, JobGraph jobGraph, JobResourceRequirements jobResourceRequirements, org.apache.flink.configuration.Configuration configuration, DeclarativeSlotPool declarativeSlotPool, SlotAllocator slotAllocator, Executor ioExecutor, ClassLoader userCodeClassLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, RestartBackoffTimeStrategy restartBackoffTimeStrategy, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory)
-
Uses of RestartBackoffTimeStrategy in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type RestartBackoffTimeStrategy Modifier and Type Method Description static AdaptiveBatchScheduler
AdaptiveBatchSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, org.apache.flink.api.common.ExecutionConfig executionConfig, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, CheckpointsCleaner checkpointsCleaner, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations, ExecutionOperations executionOperations, ExecutionSlotAllocatorFactory allocatorFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler jobRecoveryHandler)
Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type RestartBackoffTimeStrategy Constructor Description AdaptiveBatchScheduler(org.slf4j.Logger log, AdaptiveExecutionHandler adaptiveExecutionHandler, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, Consumer<org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor> startUpAction, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Duration rpcTimeout, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, int defaultMaxParallelism, BlocklistOperations blocklistOperations, org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint, BatchJobRecoveryHandler jobRecoveryHandler, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-