Modifier and Type | Method and Description |
---|---|
void |
HBaseSinkFunction.invoke(T value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
GenericJdbcSinkFunction.invoke(T value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
static <T> SinkFunction.Context<T> |
SinkContextUtil.forTimestamp(long timestamp)
Creates a
SinkFunction.Context that throws an exception when trying to access the
current watermark or processing time. |
Modifier and Type | Method and Description |
---|---|
default void |
SinkFunction.invoke(IN value,
SinkFunction.Context context)
Writes the given value to the sink.
|
void |
TwoPhaseCommitSinkFunction.invoke(IN value,
SinkFunction.Context context) |
protected abstract void |
TwoPhaseCommitSinkFunction.invoke(TXN transaction,
IN value,
SinkFunction.Context context)
Write value within a transaction.
|
Modifier and Type | Method and Description |
---|---|
void |
StreamingFileSink.invoke(IN value,
SinkFunction.Context context) |
Bucket<IN,BucketID> |
Buckets.onElement(IN value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
CollectSinkFunction.invoke(IN value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
ElasticsearchSinkBase.invoke(T value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
PubSubSink.invoke(IN message,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
FlinkKafkaProducer.invoke(FlinkKafkaProducer.KafkaTransactionState transaction,
IN next,
SinkFunction.Context context) |
void |
FlinkKafkaProducer011.invoke(FlinkKafkaProducer011.KafkaTransactionState transaction,
IN next,
SinkFunction.Context context) |
void |
FlinkKafkaProducerBase.invoke(IN next,
SinkFunction.Context context)
Called when new data arrives to the sink, and forwards it to Kafka.
|
void |
FlinkKafkaProducer010.invoke(T value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
FlinkKafkaShuffleProducer.invoke(FlinkKafkaProducer.KafkaTransactionState transaction,
IN next,
SinkFunction.Context context)
This is the function invoked to handle each element.
|
Modifier and Type | Method and Description |
---|---|
void |
FlinkKinesisProducer.invoke(OUT value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
CollectSink.invoke(IN value,
SinkFunction.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
AlertSink.invoke(Alert value,
SinkFunction.Context context) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.