Uses of Interface
org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
-
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.checkpoint
Classes in org.apache.flink.runtime.checkpoint that implement CheckpointRecoveryFactory Modifier and Type Class Description classPerJobCheckpointRecoveryFactory<T extends CompletedCheckpointStore>SimpleCheckpointRecoveryFactorywhich creates and keeps separateCompletedCheckpointStoreandCheckpointIDCounterfor eachJobID.classStandaloneCheckpointRecoveryFactoryCheckpointCoordinatorcomponents inHighAvailabilityMode.NONE.classZooKeeperCheckpointRecoveryFactoryCheckpointCoordinatorcomponents inHighAvailabilityMode.ZOOKEEPER.Methods in org.apache.flink.runtime.checkpoint that return CheckpointRecoveryFactory Modifier and Type Method Description static <T extends CompletedCheckpointStore>
CheckpointRecoveryFactoryPerJobCheckpointRecoveryFactory. withoutCheckpointStoreRecovery(IntFunction<T> storeFn) -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.dispatcher.cleanup
Methods in org.apache.flink.runtime.dispatcher.cleanup with parameters of type CheckpointRecoveryFactory Modifier and Type Method Description CheckpointResourcesCleanupRunnerCheckpointResourcesCleanupRunnerFactory. create(JobResult jobResult, CheckpointRecoveryFactory checkpointRecoveryFactory, org.apache.flink.configuration.Configuration configuration, Executor cleanupExecutor)JobManagerRunnerCleanupRunnerFactory. create(JobResult jobResult, CheckpointRecoveryFactory checkpointRecoveryFactory, org.apache.flink.configuration.Configuration configuration, Executor cleanupExecutor)Constructors in org.apache.flink.runtime.dispatcher.cleanup with parameters of type CheckpointRecoveryFactory Constructor Description CheckpointResourcesCleanupRunner(JobResult jobResult, CheckpointRecoveryFactory checkpointRecoveryFactory, SharedStateRegistryFactory sharedStateRegistryFactory, org.apache.flink.configuration.Configuration jobManagerConfiguration, Executor cleanupExecutor, long initializationTimestamp) -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.highavailability
Methods in org.apache.flink.runtime.highavailability that return CheckpointRecoveryFactory Modifier and Type Method Description protected abstract CheckpointRecoveryFactoryAbstractHaServices. createCheckpointRecoveryFactory()Create the checkpoint recovery factory for the job manager.CheckpointRecoveryFactoryAbstractHaServices. getCheckpointRecoveryFactory()CheckpointRecoveryFactoryHighAvailabilityServices. getCheckpointRecoveryFactory()Gets the checkpoint recovery factory for the job manager. -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.highavailability.nonha
Methods in org.apache.flink.runtime.highavailability.nonha that return CheckpointRecoveryFactory Modifier and Type Method Description CheckpointRecoveryFactoryAbstractNonHaServices. getCheckpointRecoveryFactory() -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.highavailability.nonha.embedded
Methods in org.apache.flink.runtime.highavailability.nonha.embedded that return CheckpointRecoveryFactory Modifier and Type Method Description CheckpointRecoveryFactoryEmbeddedHaServicesWithLeadershipControl. getCheckpointRecoveryFactory()Constructors in org.apache.flink.runtime.highavailability.nonha.embedded with parameters of type CheckpointRecoveryFactory Constructor Description EmbeddedHaServicesWithLeadershipControl(Executor executor, CheckpointRecoveryFactory checkpointRecoveryFactory) -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.highavailability.zookeeper
Methods in org.apache.flink.runtime.highavailability.zookeeper that return CheckpointRecoveryFactory Modifier and Type Method Description CheckpointRecoveryFactoryZooKeeperLeaderElectionHaServices. createCheckpointRecoveryFactory() -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type CheckpointRecoveryFactory Modifier and Type Method Description SchedulerNGDefaultSlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)SchedulerNGSlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)Creates aSchedulerNG. -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type CheckpointRecoveryFactory Modifier and Type Method Description static CheckpointIDCounterSchedulerUtils. createCheckpointIDCounterIfCheckpointingIsEnabled(JobGraph jobGraph, CheckpointRecoveryFactory checkpointRecoveryFactory)static CompletedCheckpointStoreSchedulerUtils. createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, CheckpointRecoveryFactory checkpointRecoveryFactory, Executor ioExecutor, org.slf4j.Logger log)SchedulerNGDefaultSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)SchedulerNGSchedulerNGFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)Constructors in org.apache.flink.runtime.scheduler with parameters of type CheckpointRecoveryFactory 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)SchedulerBase(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionVertexVersioner executionVertexVersioner, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, ExecutionGraphFactory executionGraphFactory, VertexParallelismStore vertexParallelismStore, ExecutionPlanSchedulingContext executionPlanSchedulingContext) -
Uses of CheckpointRecoveryFactory in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type CheckpointRecoveryFactory Modifier and Type Method Description SchedulerNGAdaptiveSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)Constructors in org.apache.flink.runtime.scheduler.adaptive with parameters of type CheckpointRecoveryFactory 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 CheckpointRecoveryFactory in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type CheckpointRecoveryFactory Modifier and Type Method Description SchedulerNGAdaptiveBatchSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)static AdaptiveBatchSchedulerAdaptiveBatchSchedulerFactory. 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 CheckpointRecoveryFactory 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)
-