Package | Description |
---|---|
org.apache.flink.connector.file.table.batch.compact | |
org.apache.flink.streaming.api.functions.sink | |
org.apache.flink.streaming.api.functions.sink.filesystem | |
org.apache.flink.streaming.api.operators.collect | |
org.apache.flink.streaming.experimental |
This package holds classes that are experimental.
|
org.apache.flink.test.streaming.runtime.util |
Modifier and Type | Class and Description |
---|---|
class |
BatchPartitionCommitterSink
Committer operator for partition in batch mode.
|
Modifier and Type | Class and Description |
---|---|
class |
OutputFormatSinkFunction<IN>
Deprecated.
Please use the
StreamingFileSink
for writing to files from a streaming program. |
class |
PrintSinkFunction<IN>
Implementation of the SinkFunction writing every tuple to the standard output or standard error
stream.
|
class |
SocketClientSink<IN>
Socket client that acts as a streaming sink.
|
class |
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
This is a recommended base class for all of the
SinkFunction that intend to implement
exactly-once semantic. |
Modifier and Type | Class and Description |
---|---|
class |
StreamingFileSink<IN>
Deprecated.
Use
FileSink instead. |
Modifier and Type | Class and Description |
---|---|
class |
CollectSinkFunction<IN>
A sink function that collects query results and sends them back to the client.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectSink<IN>
A specialized data sink to be used by DataStreamUtils.collect().
|
Modifier and Type | Class and Description |
---|---|
class |
TestListResultSink<T>
Thread-safe sink for collecting elements into an on-heap list.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.