Package | Description |
---|---|
org.apache.flink.runtime.executiongraph.failover.flip1 | |
org.apache.flink.runtime.scheduler | |
org.apache.flink.runtime.scheduler.adaptive |
Modifier and Type | Class and 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.
|
Modifier and Type | Method and Description |
---|---|
RestartBackoffTimeStrategy |
ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory.create() |
RestartBackoffTimeStrategy |
FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory.create() |
RestartBackoffTimeStrategy |
FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory.create() |
RestartBackoffTimeStrategy |
NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory.create() |
RestartBackoffTimeStrategy |
RestartBackoffTimeStrategy.Factory.create()
Instantiates the
RestartBackoffTimeStrategy . |
Constructor and Description |
---|
ExecutionFailureHandler(SchedulingTopology schedulingTopology,
FailoverStrategy failoverStrategy,
RestartBackoffTimeStrategy restartBackoffTimeStrategy)
Creates the handler to deal with task failures.
|
Constructor and Description |
---|
DefaultScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
java.util.function.Consumer<ComponentMainThreadExecutor> startUpAction,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ExecutionVertexOperations executionVertexOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismStore vertexParallelismStore) |
Constructor and Description |
---|
AdaptiveScheduler(JobGraph jobGraph,
Configuration configuration,
DeclarativeSlotPool declarativeSlotPool,
SlotAllocator slotAllocator,
Executor ioExecutor,
ClassLoader userCodeClassLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
java.time.Duration initialResourceAllocationTimeout,
java.time.Duration resourceStabilizationTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.