Modifier and Type | Class and Description |
---|---|
class |
PrintSinkOutputWriter<IN>
Print sink output writer for DataStream and DataSet print API.
|
Modifier and Type | Interface and Description |
---|---|
static interface |
StatefulSink.StatefulSinkWriter<InputT,WriterStateT>
A
SinkWriter whose state needs to be checkpointed. |
static interface |
TwoPhaseCommittingSink.PrecommittingSinkWriter<InputT,CommT>
A
SinkWriter that performs the first part of a two-phase commit protocol. |
Modifier and Type | Method and Description |
---|---|
SinkWriter<InputT> |
Sink.createWriter(Sink.InitContext context)
Creates a
SinkWriter . |
Modifier and Type | Class and Description |
---|---|
class |
AsyncSinkWriter<InputT,RequestEntryT extends Serializable>
A generic sink writer that handles the general behaviour of a sink such as batching and flushing,
and allows extenders to implement the logic for persisting individual request elements, with
allowance for retries.
|
Modifier and Type | Class and Description |
---|---|
class |
FileWriter<IN>
A
SinkWriter implementation for FileSink . |
Modifier and Type | Method and Description |
---|---|
SinkWriter<IN> |
UpsertTestSink.createWriter(Sink.InitContext context) |
Modifier and Type | Method and Description |
---|---|
SinkWriter<IN> |
PrintSink.createWriter(Sink.InitContext context) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.