CommT
- The type of information needed to commit the staged data@PublicEvolving public interface Committer<CommT> extends AutoCloseable
Committer
is responsible for committing the data staged by the TwoPhaseCommittingSink.PrecommittingSinkWriter
in the second step of a two-phase commit
protocol.
A commit must be idempotent: If some failure occurs in Flink during commit phase, Flink will
restart from previous checkpoint and re-attempt to commit all committables. Thus, some or all
committables may have already been committed. These Committer.CommitRequest
s must not change the
external system and implementers are asked to signal Committer.CommitRequest.signalAlreadyCommitted()
.
Modifier and Type | Interface and Description |
---|---|
static interface |
Committer.CommitRequest<CommT>
A request to commit a specific committable.
|
Modifier and Type | Method and Description |
---|---|
void |
commit(Collection<Committer.CommitRequest<CommT>> committables)
Commit the given list of
CommT . |
close
void commit(Collection<Committer.CommitRequest<CommT>> committables) throws IOException, InterruptedException
CommT
.committables
- A list of commit requests staged by the sink writer.IOException
- for reasons that may yield a complete restart of the job.InterruptedException
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.