IN
- Input record type@PublicEvolving public class PrintSink<IN> extends Object implements org.apache.flink.api.connector.sink2.Sink<IN>, org.apache.flink.api.common.SupportsConcurrentExecutionAttempts
Four possible format options:
sinkIdentifier
:subtaskIndex> output <- sinkIdentifier
provided and
parallelism > 1,
sinkIdentifier
> output <- sinkIdentifier
provided and parallelism == 1
sinkIdentifier
provided and parallelism > 1
sinkIdentifier
provided and parallelism == 1
Constructor and Description |
---|
PrintSink()
Instantiates a print sink function that prints to STDOUT.
|
PrintSink(boolean stdErr)
Instantiates a print sink that prints to STDOUT or STDERR.
|
PrintSink(String sinkIdentifier)
Instantiates a print sink that prints to STDOUT and gives a sink identifier.
|
PrintSink(String sinkIdentifier,
boolean stdErr)
Instantiates a print sink that prints to STDOUT or STDERR and gives a sink identifier.
|
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.connector.sink2.SinkWriter<IN> |
createWriter(org.apache.flink.api.connector.sink2.Sink.InitContext context) |
String |
toString() |
public PrintSink()
public PrintSink(boolean stdErr)
stdErr
- True, if the format should print to standard error instead of standard out.public PrintSink(String sinkIdentifier)
sinkIdentifier
- Message that identifies the sink and is prefixed to the output of the
valuepublic PrintSink(String sinkIdentifier, boolean stdErr)
sinkIdentifier
- Message that identifies the sink and is prefixed to the output of the
valuestdErr
- True if the sink should print to STDERR instead of STDOUT.public org.apache.flink.api.connector.sink2.SinkWriter<IN> createWriter(org.apache.flink.api.connector.sink2.Sink.InitContext context) throws IOException
createWriter
in interface org.apache.flink.api.connector.sink2.Sink<IN>
IOException
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.