Class CassandraCommitter

  • All Implemented Interfaces:
    Serializable

    public class CassandraCommitter
    extends org.apache.flink.streaming.runtime.operators.CheckpointCommitter
    CheckpointCommitter that saves information about completed checkpoints within a separate table in a cassandra database.

    Entries are in the form |operator_id | subtask_id | last_completed_checkpoint|

    See Also:
    Serialized Form
    • Constructor Detail

      • CassandraCommitter

        public CassandraCommitter​(ClusterBuilder builder)
    • Method Detail

      • setJobId

        public void setJobId​(String id)
                      throws Exception
        Internally used to set the job ID after instantiation.
        Overrides:
        setJobId in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
        Throws:
        Exception
      • createResource

        public void createResource()
                            throws Exception
        Generates the necessary tables to store information.
        Specified by:
        createResource in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
        Throws:
        Exception
      • open

        public void open()
                  throws Exception
        Specified by:
        open in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
        Throws:
        Exception
      • close

        public void close()
                   throws Exception
        Specified by:
        close in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
        Throws:
        Exception
      • commitCheckpoint

        public void commitCheckpoint​(int subtaskIdx,
                                     long checkpointId)
        Specified by:
        commitCheckpoint in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
      • isCheckpointCommitted

        public boolean isCheckpointCommitted​(int subtaskIdx,
                                             long checkpointId)
        Specified by:
        isCheckpointCommitted in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter