Package | Description |
---|---|
org.apache.flink.streaming.api.functions.sink | |
org.apache.flink.streaming.api.functions.sink.filesystem | |
org.apache.flink.streaming.experimental |
This package holds classes that are experimental.
|
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) |
Modifier and Type | Method and Description |
---|---|
void |
CollectSink.invoke(IN value,
SinkFunction.Context context) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.