Interface PeriodicMaterializationManager.MaterializationTarget

    • Method Detail

      • initMaterialization

        Optional<PeriodicMaterializationManager.MaterializationRunnable> initMaterialization()
                                                                                      throws Exception
        Initialize state materialization so that materialized data can be persisted durably and included into the checkpoint.
        Returns:
        a tuple of - future snapshot result from the underlying state backend - a SequenceNumber identifying the latest change in the changelog
        Throws:
        Exception
      • handleMaterializationResult

        void handleMaterializationResult​(org.apache.flink.runtime.state.SnapshotResult<org.apache.flink.runtime.state.KeyedStateHandle> materializedSnapshot,
                                         long materializationID,
                                         org.apache.flink.runtime.state.changelog.SequenceNumber upTo)
                                  throws Exception
        Implementations should not trigger materialization until the previous one has been confirmed or failed.
        Throws:
        Exception
      • handleMaterializationFailureOrCancellation

        void handleMaterializationFailureOrCancellation​(long materializationID,
                                                        org.apache.flink.runtime.state.changelog.SequenceNumber upTo,
                                                        Throwable cause)