void |
PhysicalFilePool.close(FileMergingSnapshotManager.SubtaskKey subtaskKey) |
Close files in shared file pool by subtaskKey and close all files in exclusive file pool.
|
FileMergingCheckpointStateOutputStream |
FileMergingSnapshotManager.createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
|
FileMergingCheckpointStateOutputStream |
FileMergingSnapshotManagerBase.createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
|
protected LogicalFile |
FileMergingSnapshotManagerBase.createLogicalFile(PhysicalFile physicalFile,
long startOffset,
long length,
FileMergingSnapshotManager.SubtaskKey subtaskKey) |
Create a logical file on a physical file.
|
protected PhysicalFile |
FileMergingSnapshotManagerBase.createPhysicalFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
Create a physical file in right location (managed directory), which is specified by scope of
this checkpoint and current subtask.
|
protected Queue<PhysicalFile> |
PhysicalFilePool.getFileQueue(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
Get or create a file queue for specific subtaskKey and checkpoint scope.
|
org.apache.flink.core.fs.Path |
FileMergingSnapshotManager.getManagedDir(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
org.apache.flink.core.fs.Path |
FileMergingSnapshotManagerBase.getManagedDir(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
DirectoryStreamStateHandle |
FileMergingSnapshotManager.getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
DirectoryStreamStateHandle |
FileMergingSnapshotManagerBase.getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
protected PhysicalFile |
AcrossCheckpointFileMergingSnapshotManager.getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointID,
CheckpointedStateScope scope) |
|
protected abstract PhysicalFile |
FileMergingSnapshotManagerBase.getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
Get a reused physical file or create one.
|
protected PhysicalFile |
WithinCheckpointFileMergingSnapshotManager.getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
CheckpointedStateScope scope) |
|
void |
FileMergingSnapshotManager.notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
This method is called as a notification once a distributed checkpoint has been aborted.
|
void |
FileMergingSnapshotManagerBase.notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
|
void |
WithinCheckpointFileMergingSnapshotManager.notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
|
void |
FileMergingSnapshotManager.notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
Notifies the manager that the checkpoint with the given checkpointId completed and
was committed.
|
void |
FileMergingSnapshotManagerBase.notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
|
void |
WithinCheckpointFileMergingSnapshotManager.notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
|
void |
FileMergingSnapshotManager.notifyCheckpointStart(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
Notifies the manager that the checkpoint with the given checkpointId has been
started.
|
void |
FileMergingSnapshotManagerBase.notifyCheckpointStart(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
SubtaskCheckpointCoordinatorImpl use this
method let the file merging manager know an ongoing checkpoint may reference the managed
dirs.
|
void |
FileMergingSnapshotManager.notifyCheckpointSubsumed(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
This method is called as a notification once a distributed checkpoint has been subsumed.
|
void |
FileMergingSnapshotManagerBase.notifyCheckpointSubsumed(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId) |
|
PhysicalFile |
PhysicalFile.PhysicalFileCreator.perform(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
Create the file.
|
PhysicalFile |
BlockingPhysicalFilePool.pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
PhysicalFile |
NonBlockingPhysicalFilePool.pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
|
abstract PhysicalFile |
PhysicalFilePool.pollFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
CheckpointedStateScope scope) |
Poll a physical file from the pool.
|
void |
FileMergingSnapshotManager.registerSubtaskForSharedStates(FileMergingSnapshotManager.SubtaskKey subtaskKey) |
Register a subtask and create the managed directory for shared states.
|
void |
FileMergingSnapshotManagerBase.registerSubtaskForSharedStates(FileMergingSnapshotManager.SubtaskKey subtaskKey) |
|
void |
FileMergingSnapshotManager.restoreStateHandles(long checkpointId,
FileMergingSnapshotManager.SubtaskKey subtaskKey,
Stream<SegmentFileStateHandle> stateHandles) |
Restore and re-register the SegmentFileStateHandles into FileMergingSnapshotManager.
|
void |
FileMergingSnapshotManagerBase.restoreStateHandles(long checkpointId,
FileMergingSnapshotManager.SubtaskKey subtaskKey,
Stream<SegmentFileStateHandle> stateHandles) |
|
protected void |
AcrossCheckpointFileMergingSnapshotManager.returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
PhysicalFile physicalFile) |
|
protected abstract void |
FileMergingSnapshotManagerBase.returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
PhysicalFile physicalFile) |
Try to return an existing physical file to the manager for next reuse.
|
protected void |
WithinCheckpointFileMergingSnapshotManager.returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey subtaskKey,
long checkpointId,
PhysicalFile physicalFile) |
|
boolean |
BlockingPhysicalFilePool.tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
PhysicalFile physicalFile) |
|
boolean |
NonBlockingPhysicalFilePool.tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
PhysicalFile physicalFile) |
|
abstract boolean |
PhysicalFilePool.tryPutFile(FileMergingSnapshotManager.SubtaskKey subtaskKey,
PhysicalFile physicalFile) |
Try to put a physical file into file pool.
|
void |
FileMergingSnapshotManager.unregisterSubtask(FileMergingSnapshotManager.SubtaskKey subtaskKey) |
Unregister a subtask.
|
void |
FileMergingSnapshotManagerBase.unregisterSubtask(FileMergingSnapshotManager.SubtaskKey subtaskKey) |
|