Package | Description |
---|---|
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.messages.checkpoint |
This package contains the messages that are sent between
JobMaster and TaskExecutor to coordinate the checkpoint snapshots of the
distributed dataflow. |
org.apache.flink.runtime.scheduler | |
org.apache.flink.runtime.scheduler.adaptive |
Class and Description |
---|
AcknowledgeCheckpoint
This message is sent from the
TaskExecutor to the
JobMaster to signal that the checkpoint of an
individual task is completed. |
DeclineCheckpoint
This message is sent from the
TaskExecutor to the
JobMaster to tell the checkpoint coordinator that a
checkpoint request could not be heeded. |
Class and Description |
---|
DeclineCheckpoint
This message is sent from the
TaskExecutor to the
JobMaster to tell the checkpoint coordinator that a
checkpoint request could not be heeded. |
Class and Description |
---|
AbstractCheckpointMessage
The base class of all checkpoint messages.
|
SerializedCheckpointException
Serialized checkpoint exception which wraps the checkpoint failure reason and its serialized
throwable.
|
Class and Description |
---|
DeclineCheckpoint
This message is sent from the
TaskExecutor to the
JobMaster to tell the checkpoint coordinator that a
checkpoint request could not be heeded. |
Class and Description |
---|
DeclineCheckpoint
This message is sent from the
TaskExecutor to the
JobMaster to tell the checkpoint coordinator that a
checkpoint request could not be heeded. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.