InputT
- The type of the sink's inputCommT
- The type of the committables.Sink
SupportsCommitter
instead.@PublicEvolving @Deprecated public interface TwoPhaseCommittingSink<InputT,CommT> extends Sink<InputT>, SupportsCommitter<CommT>
Sink
for exactly-once semantics using a two-phase commit protocol. The Sink
consists of a SinkWriter
that performs the precommits and a Committer
that
actually commits the data. To facilitate the separation the SinkWriter
creates
committables on checkpoint or end of input and the sends it to the Committer
.
The TwoPhaseCommittingSink
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 | Interface and Description |
---|---|
static interface |
TwoPhaseCommittingSink.PrecommittingSinkWriter<InputT,CommT>
Deprecated.
|
Sink.InitContext, Sink.InitContextWrapper
Modifier and Type | Method and Description |
---|---|
default Committer<CommT> |
createCommitter()
Deprecated.
Please use
createCommitter(CommitterInitContext) |
default Committer<CommT> |
createCommitter(CommitterInitContext context)
Deprecated.
Creates a
Committer that permanently makes the previously written data visible
through Committer.commit(Collection) . |
createWriter, createWriter
getCommittableSerializer
@Deprecated default Committer<CommT> createCommitter() throws IOException
createCommitter(CommitterInitContext)
Committer
that permanently makes the previously written data visible
through Committer.commit(Collection)
.IOException
- for any failure during creation.default Committer<CommT> createCommitter(CommitterInitContext context) throws IOException
Committer
that permanently makes the previously written data visible
through Committer.commit(Collection)
.createCommitter
in interface SupportsCommitter<CommT>
context
- The context information for the committer initialization.IOException
- for any failure during creation.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.