Interface | Description |
---|---|
Committer<CommT> |
The
Committer is responsible for committing the data staged by the TwoPhaseCommittingSink.PrecommittingSinkWriter in the second step of a two-phase commit
protocol. |
Committer.CommitRequest<CommT> |
A request to commit a specific committable.
|
Sink<InputT> |
Base interface for developing a sink.
|
Sink.InitContext |
The interface exposes some runtime info for creating a
SinkWriter . |
SinkWriter<InputT> |
The
SinkWriter is responsible for writing data. |
SinkWriter.Context |
Context that
SinkWriter.write(InputT, org.apache.flink.api.connector.sink2.SinkWriter.Context) can use for getting additional data about an input record. |
StatefulSink<InputT,WriterStateT> |
A
Sink with a stateful SinkWriter . |
StatefulSink.StatefulSinkWriter<InputT,WriterStateT> |
A
SinkWriter whose state needs to be checkpointed. |
StatefulSink.WithCompatibleState |
A mix-in for
StatefulSink that allows users to migrate from a sink with a compatible
state to this sink. |
TwoPhaseCommittingSink<InputT,CommT> |
A
Sink for exactly-once semantics using a two-phase commit protocol. |
TwoPhaseCommittingSink.PrecommittingSinkWriter<InputT,CommT> |
A
SinkWriter that performs the first part of a two-phase commit protocol. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.