Class AbstractCheckpointStats
- java.lang.Object
-
- org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
- All Implemented Interfaces:
Serializable
- Direct Known Subclasses:
CompletedCheckpointStats,PendingCheckpointStats
public abstract class AbstractCheckpointStats extends Object implements Serializable
Base class for checkpoint statistics.- See Also:
- Serialized Form
-
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description Collection<TaskStateStats>getAllTaskStateStats()Returns all task state stats instances.abstract longgetCheckpointedSize()Returns the checkpointed size during that checkpoint.longgetCheckpointId()Returns the ID of this checkpoint.longgetEndToEndDuration()Returns the duration of this checkpoint calculated as the time since triggering until the latest acknowledged subtask or-1if no subtask was acknowledged yet.abstract SubtaskStateStatsgetLatestAcknowledgedSubtaskStats()Returns the latest acknowledged subtask stats ornullif none was acknowledged yet.longgetLatestAckTimestamp()Returns the ack timestamp of the latest acknowledged subtask or-1if none was acknowledged yet.abstract intgetNumberOfAcknowledgedSubtasks()Returns the number of acknowledged subtasks.intgetNumberOfSubtasks()Returns the total number of subtasks involved in this checkpoint.abstract longgetPersistedData()abstract longgetProcessedData()CheckpointPropertiesgetProperties()Returns the properties of this checkpoint.abstract longgetStateSize()Returns the total checkpoint state size over all subtasks.abstract CheckpointStatsStatusgetStatus()Returns the status of this checkpoint.TaskStateStatsgetTaskStateStats(JobVertexID jobVertexId)Returns the task state stats for the given job vertex ID ornullif no task with such an ID is available.longgetTriggerTimestamp()Returns the timestamp when the checkpoint was triggered.abstract booleanisUnalignedCheckpoint()
-
-
-
Method Detail
-
getStatus
public abstract CheckpointStatsStatus getStatus()
Returns the status of this checkpoint.- Returns:
- Status of this checkpoint
-
getNumberOfAcknowledgedSubtasks
public abstract int getNumberOfAcknowledgedSubtasks()
Returns the number of acknowledged subtasks.- Returns:
- The number of acknowledged subtasks.
-
getStateSize
public abstract long getStateSize()
Returns the total checkpoint state size over all subtasks.- Returns:
- Total checkpoint state size over all subtasks.
-
getCheckpointedSize
public abstract long getCheckpointedSize()
Returns the checkpointed size during that checkpoint.- Returns:
- The checkpointed size during that checkpoint.
-
getProcessedData
public abstract long getProcessedData()
- Returns:
- the total number of processed bytes during the checkpoint.
-
getPersistedData
public abstract long getPersistedData()
- Returns:
- the total number of persisted bytes during the checkpoint.
-
isUnalignedCheckpoint
public abstract boolean isUnalignedCheckpoint()
- Returns:
- whether the checkpoint is unaligned.
-
getLatestAcknowledgedSubtaskStats
@Nullable public abstract SubtaskStateStats getLatestAcknowledgedSubtaskStats()
Returns the latest acknowledged subtask stats ornullif none was acknowledged yet.- Returns:
- Latest acknowledged subtask stats or
null
-
getCheckpointId
public long getCheckpointId()
Returns the ID of this checkpoint.- Returns:
- ID of this checkpoint.
-
getTriggerTimestamp
public long getTriggerTimestamp()
Returns the timestamp when the checkpoint was triggered.- Returns:
- Timestamp when the checkpoint was triggered.
-
getProperties
public CheckpointProperties getProperties()
Returns the properties of this checkpoint.- Returns:
- Properties of this checkpoint.
-
getNumberOfSubtasks
public int getNumberOfSubtasks()
Returns the total number of subtasks involved in this checkpoint.- Returns:
- Total number of subtasks involved in this checkpoint.
-
getTaskStateStats
public TaskStateStats getTaskStateStats(JobVertexID jobVertexId)
Returns the task state stats for the given job vertex ID ornullif no task with such an ID is available.- Parameters:
jobVertexId- Job vertex ID of the task stats to look up.- Returns:
- The task state stats instance for the given ID or
null.
-
getAllTaskStateStats
public Collection<TaskStateStats> getAllTaskStateStats()
Returns all task state stats instances.- Returns:
- All task state stats instances.
-
getLatestAckTimestamp
public long getLatestAckTimestamp()
Returns the ack timestamp of the latest acknowledged subtask or-1if none was acknowledged yet.- Returns:
- Ack timestamp of the latest acknowledged subtask or
-1.
-
getEndToEndDuration
public long getEndToEndDuration()
Returns the duration of this checkpoint calculated as the time since triggering until the latest acknowledged subtask or-1if no subtask was acknowledged yet.- Returns:
- Duration of this checkpoint or
-1if no subtask was acknowledged yet.
-
-