Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
org.apache.flink.runtime.state.memory |
Constructor and Description |
---|
PendingCheckpoint(JobID jobId,
long checkpointId,
long checkpointTimestamp,
Map<ExecutionAttemptID,ExecutionVertex> verticesToConfirm,
Collection<String> masterStateIdentifiers,
CheckpointProperties props,
CheckpointStorageLocation targetLocation,
Executor executor) |
Modifier and Type | Method and Description |
---|---|
CheckpointStorageLocation |
CheckpointStorageCoordinatorView.initializeLocationForCheckpoint(long checkpointId)
Initializes a storage location for new checkpoint with the given ID.
|
CheckpointStorageLocation |
CheckpointStorageCoordinatorView.initializeLocationForSavepoint(long checkpointId,
String externalLocationPointer)
Initializes a storage location for new savepoint with the given ID.
|
Modifier and Type | Class and Description |
---|---|
class |
FsCheckpointStorageLocation
A storage location for checkpoints on a file system.
|
Modifier and Type | Method and Description |
---|---|
protected CheckpointStorageLocation |
FsCheckpointStorage.createSavepointLocation(FileSystem fs,
Path location) |
protected abstract CheckpointStorageLocation |
AbstractFsCheckpointStorage.createSavepointLocation(FileSystem fs,
Path location) |
CheckpointStorageLocation |
FsCheckpointStorage.initializeLocationForCheckpoint(long checkpointId) |
CheckpointStorageLocation |
AbstractFsCheckpointStorage.initializeLocationForSavepoint(long checkpointId,
String externalLocationPointer)
Creates a file system based storage location for a savepoint.
|
Modifier and Type | Class and Description |
---|---|
class |
NonPersistentMetadataCheckpointStorageLocation
A checkpoint storage location for the
MemoryStateBackend in case no durable persistence
for metadata has been configured. |
class |
PersistentMetadataCheckpointStorageLocation
A checkpoint storage location for the
MemoryStateBackend when it durably
persists the metadata in a file system. |
Modifier and Type | Method and Description |
---|---|
protected CheckpointStorageLocation |
MemoryBackendCheckpointStorage.createSavepointLocation(FileSystem fs,
Path location) |
CheckpointStorageLocation |
MemoryBackendCheckpointStorage.initializeLocationForCheckpoint(long checkpointId) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.