Uses of Interface
org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Packages that use FileMergingSnapshotManager Package Description org.apache.flink.runtime.checkpoint.filemerging org.apache.flink.runtime.state org.apache.flink.runtime.state.filesystem -
-
Uses of FileMergingSnapshotManager in org.apache.flink.runtime.checkpoint.filemerging
Classes in org.apache.flink.runtime.checkpoint.filemerging that implement FileMergingSnapshotManager Modifier and Type Class Description classAcrossCheckpointFileMergingSnapshotManagerAFileMergingSnapshotManagerthat merging files across checkpoints.classFileMergingSnapshotManagerBaseBase implementation ofFileMergingSnapshotManager.classWithinCheckpointFileMergingSnapshotManagerAFileMergingSnapshotManagerthat merging files within a checkpoint.Methods in org.apache.flink.runtime.checkpoint.filemerging that return FileMergingSnapshotManager Modifier and Type Method Description FileMergingSnapshotManagerFileMergingSnapshotManagerBuilder. build()Create file-merging snapshot manager based on configuration.Constructors in org.apache.flink.runtime.checkpoint.filemerging with parameters of type FileMergingSnapshotManager Constructor Description SubtaskFileMergingManagerRestoreOperation(long checkpointId, FileMergingSnapshotManager fileMergingSnapshotManager, org.apache.flink.api.common.JobID jobID, org.apache.flink.api.common.TaskInfo taskInfo, JobVertexID vertexID, OperatorSubtaskState subtaskState) -
Uses of FileMergingSnapshotManager in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return FileMergingSnapshotManager Modifier and Type Method Description FileMergingSnapshotManagerTaskExecutorFileMergingManager. fileMergingSnapshotManagerForTask(org.apache.flink.api.common.JobID jobId, ResourceID tmResourceId, ExecutionAttemptID executionAttemptID, org.apache.flink.configuration.Configuration clusterConfiguration, org.apache.flink.configuration.Configuration jobConfiguration, TaskManagerJobMetricGroup metricGroup)Initialize file merging snapshot manager for each job according configurations whenTaskExecutor.submitTask(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor, org.apache.flink.runtime.jobmaster.JobMasterId, java.time.Duration).FileMergingSnapshotManagerFileMergingSnapshotManagerClosableWrapper. get()FileMergingSnapshotManagerTaskStateManager. getFileMergingSnapshotManager()FileMergingSnapshotManagerTaskStateManagerImpl. getFileMergingSnapshotManager()Methods in org.apache.flink.runtime.state with parameters of type FileMergingSnapshotManager Modifier and Type Method Description static FileMergingSnapshotManagerClosableWrapperFileMergingSnapshotManagerClosableWrapper. of(FileMergingSnapshotManager snapshotManager, Closeable closeable)default CheckpointStorageWorkerViewCheckpointStorageWorkerView. toFileMergingStorage(FileMergingSnapshotManager mergingSnapshotManager, Environment environment)ReturnFsMergingCheckpointStorageAccessif file merging is enabled. -
Uses of FileMergingSnapshotManager in org.apache.flink.runtime.state.filesystem
Methods in org.apache.flink.runtime.state.filesystem with parameters of type FileMergingSnapshotManager Modifier and Type Method Description FsMergingCheckpointStorageAccessFsCheckpointStorageAccess. toFileMergingStorage(FileMergingSnapshotManager mergingSnapshotManager, Environment environment)Constructors in org.apache.flink.runtime.state.filesystem with parameters of type FileMergingSnapshotManager Constructor Description FsMergingCheckpointStorageAccess(org.apache.flink.core.fs.Path checkpointBaseDirectory, org.apache.flink.core.fs.Path defaultSavepointDirectory, org.apache.flink.api.common.JobID jobId, int fileSizeThreshold, int writeBufferSize, FileMergingSnapshotManager fileMergingSnapshotManager, Environment environment)FsMergingCheckpointStorageLocation(FileMergingSnapshotManager.SubtaskKey subtaskKey, org.apache.flink.core.fs.FileSystem fileSystem, org.apache.flink.core.fs.Path checkpointDir, org.apache.flink.core.fs.Path sharedStateDir, org.apache.flink.core.fs.Path taskOwnedStateDir, CheckpointStorageLocationReference reference, int fileStateSizeThreshold, int writeBufferSize, FileMergingSnapshotManager fileMergingSnapshotManager, long checkpointId)
-