CommittableT
- The type of the committables.@Public public interface SupportsCommitter<CommittableT>
Sink
which supports exactly-once semantics using a two-phase
commit protocol. The Sink
consists of a CommittingSinkWriter
that performs the
precommits and a Committer
that actually commits the data. To facilitate the separation
the CommittingSinkWriter
creates committables on checkpoint or end of input and
the sends it to the Committer
.
The Sink
needs to be serializable. All configuration should be validated eagerly. The
respective sink writers and committers are transient and will only be created in the subtasks on
the taskmanagers.
Modifier and Type | Method and Description |
---|---|
Committer<CommittableT> |
createCommitter(CommitterInitContext context)
Creates a
Committer that permanently makes the previously written data visible
through Committer.commit(Collection) . |
SimpleVersionedSerializer<CommittableT> |
getCommittableSerializer()
Returns the serializer of the committable type.
|
Committer<CommittableT> createCommitter(CommitterInitContext context) throws IOException
Committer
that permanently makes the previously written data visible
through Committer.commit(Collection)
.context
- The context information for the committer initialization.IOException
- for any failure during creation.SimpleVersionedSerializer<CommittableT> getCommittableSerializer()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.