Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
-
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointStatsSnapshot Modifier and Type Method Description CheckpointStatsSnapshotCheckpointStatsTracker. createSnapshot()Creates a new snapshot of the available stats.CheckpointStatsSnapshotDefaultCheckpointStatsTracker. createSnapshot()CheckpointStatsSnapshotNoOpCheckpointStatsTracker. createSnapshot()static CheckpointStatsSnapshotCheckpointStatsSnapshot. empty() -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher that return types with arguments of type CheckpointStatsSnapshot Modifier and Type Method Description CompletableFuture<CheckpointStatsSnapshot>Dispatcher. requestCheckpointStats(org.apache.flink.api.common.JobID jobId, Duration timeout) -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return CheckpointStatsSnapshot Modifier and Type Method Description CheckpointStatsSnapshotAccessExecutionGraph. getCheckpointStatsSnapshot()Returns a snapshot of the checkpoint statistics ornullif checkpointing is disabled.CheckpointStatsSnapshotArchivedExecutionGraph. getCheckpointStatsSnapshot()CheckpointStatsSnapshotDefaultExecutionGraph. getCheckpointStatsSnapshot()Constructors in org.apache.flink.runtime.executiongraph with parameters of type CheckpointStatsSnapshot Constructor Description ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, org.apache.flink.api.common.JobStatus state, JobType jobType, ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators, org.apache.flink.api.common.ArchivedExecutionConfig executionConfig, boolean isStoppable, CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, CheckpointStatsSnapshot checkpointStatsSnapshot, String stateBackendName, String checkpointStorageName, org.apache.flink.util.TernaryBoolean stateChangelogEnabled, String changelogStorageName, String streamGraphJson, int pendingOperatorCount) -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type CheckpointStatsSnapshot Modifier and Type Method Description CompletableFuture<CheckpointStatsSnapshot>JobMaster. requestCheckpointStats(Duration timeout)CompletableFuture<CheckpointStatsSnapshot>JobMasterGateway. requestCheckpointStats(Duration timeout)Requests theCheckpointStatsSnapshotof the job. -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.rest.handler.job.checkpoints
Methods in org.apache.flink.runtime.rest.handler.job.checkpoints with parameters of type CheckpointStatsSnapshot Modifier and Type Method Description protected RAbstractCheckpointHandler. handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody> request, CheckpointStatsSnapshot checkpointStatsSnapshot)protected abstract RAbstractCheckpointStatsHandler. handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody> request, CheckpointStatsSnapshot checkpointStatsSnapshot)protected CheckpointingStatisticsCheckpointingStatisticsHandler. handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody> request, CheckpointStatsSnapshot checkpointStatsSnapshot)Constructor parameters in org.apache.flink.runtime.rest.handler.job.checkpoints with type arguments of type CheckpointStatsSnapshot Constructor Description AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)AbstractCheckpointStatsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, Executor executor)CheckpointingStatisticsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,CheckpointingStatistics,JobMessageParameters> messageHeaders, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, Executor executor)CheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,CheckpointStatistics,CheckpointMessageParameters> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)TaskCheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,TaskCheckpointStatisticsWithSubtaskDetails,TaskCheckpointMessageParameters> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache) -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return CheckpointStatsSnapshot Modifier and Type Method Description CheckpointStatsSnapshotSchedulerBase. requestCheckpointStats()CheckpointStatsSnapshotSchedulerNG. requestCheckpointStats()Returns the checkpoint statistics for a given job. -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return CheckpointStatsSnapshot Modifier and Type Method Description CheckpointStatsSnapshotAdaptiveScheduler. requestCheckpointStats() -
Uses of CheckpointStatsSnapshot in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor that return types with arguments of type CheckpointStatsSnapshot Modifier and Type Method Description CompletableFuture<CheckpointStatsSnapshot>NonLeaderRetrievalRestfulGateway. requestCheckpointStats(org.apache.flink.api.common.JobID jobId, Duration timeout)CompletableFuture<CheckpointStatsSnapshot>RestfulGateway. requestCheckpointStats(org.apache.flink.api.common.JobID jobId, Duration timeout)Requests theCheckpointStatsSnapshotcontaining checkpointing information.
-