Class AsyncDynamicTableSink<RequestEntryT extends Serializable>
- java.lang.Object
-
- org.apache.flink.connector.base.table.sink.AsyncDynamicTableSink<RequestEntryT>
-
- Type Parameters:
RequestEntryT
- Request entry type forAsyncSinkBase
.
- All Implemented Interfaces:
DynamicTableSink
@PublicEvolving public abstract class AsyncDynamicTableSink<RequestEntryT extends Serializable> extends Object implements DynamicTableSink
Abstract wrapper class forDynamicTableSink
with attributes ofAsyncSinkBase
. Concrete Async Sink implementations should extend this class to add Table API support.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.table.connector.sink.DynamicTableSink
DynamicTableSink.Context, DynamicTableSink.DataStructureConverter, DynamicTableSink.SinkRuntimeProvider
-
-
Field Summary
Fields Modifier and Type Field Description protected Integer
maxBatchSize
protected Integer
maxBufferedRequests
protected Long
maxBufferSizeInBytes
protected Integer
maxInFlightRequests
protected Long
maxTimeInBufferMS
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected AsyncSinkBaseBuilder<?,RequestEntryT,?>
addAsyncOptionsToSinkBuilder(AsyncSinkBaseBuilder<?,RequestEntryT,?> builder)
boolean
equals(Object o)
int
hashCode()
-
Methods inherited from class java.lang.Object
clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.connector.sink.DynamicTableSink
asSummaryString, copy, getChangelogMode, getSinkRuntimeProvider
-
-
-
-
Field Detail
-
maxBatchSize
protected final Integer maxBatchSize
-
maxInFlightRequests
protected final Integer maxInFlightRequests
-
maxBufferedRequests
protected final Integer maxBufferedRequests
-
maxBufferSizeInBytes
protected final Long maxBufferSizeInBytes
-
maxTimeInBufferMS
protected final Long maxTimeInBufferMS
-
-
Method Detail
-
addAsyncOptionsToSinkBuilder
protected AsyncSinkBaseBuilder<?,RequestEntryT,?> addAsyncOptionsToSinkBuilder(AsyncSinkBaseBuilder<?,RequestEntryT,?> builder)
-
-