Package | Description |
---|---|
org.apache.flink.api.java | |
org.apache.flink.api.java.operators | |
org.apache.flink.api.java.utils |
Modifier and Type | Method and Description |
---|---|
DataSink<T> |
DataSet.output(OutputFormat<T> outputFormat)
Deprecated.
Emits a DataSet using an
OutputFormat . |
DataSink<T> |
DataSet.print(String sinkIdentifier)
Deprecated.
Use
DataSet.printOnTaskManager(String) instead. |
DataSink<T> |
DataSet.printOnTaskManager(String prefix)
Deprecated.
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the
program (or more specifically, the data sink operators).
|
DataSink<T> |
DataSet.printToErr(String sinkIdentifier)
Deprecated.
Use
DataSet.printOnTaskManager(String) instead, or the PrintingOutputFormat . |
DataSink<T> |
DataSet.write(FileOutputFormat<T> outputFormat,
String filePath)
Deprecated.
Writes a DataSet using a
FileOutputFormat to a specified location. |
DataSink<T> |
DataSet.write(FileOutputFormat<T> outputFormat,
String filePath,
FileSystem.WriteMode writeMode)
Deprecated.
Writes a DataSet using a
FileOutputFormat to a specified location. |
DataSink<T> |
DataSet.writeAsCsv(String filePath)
Deprecated.
Writes a
Tuple DataSet as CSV file(s) to the specified location. |
DataSink<T> |
DataSet.writeAsCsv(String filePath,
FileSystem.WriteMode writeMode)
Deprecated.
Writes a
Tuple DataSet as CSV file(s) to the specified location. |
DataSink<T> |
DataSet.writeAsCsv(String filePath,
String rowDelimiter,
String fieldDelimiter)
Deprecated.
Writes a
Tuple DataSet as CSV file(s) to the specified location with the specified
field and line delimiters. |
DataSink<T> |
DataSet.writeAsCsv(String filePath,
String rowDelimiter,
String fieldDelimiter,
FileSystem.WriteMode writeMode)
Deprecated.
Writes a
Tuple DataSet as CSV file(s) to the specified location with the specified
field and line delimiters. |
DataSink<String> |
DataSet.writeAsFormattedText(String filePath,
FileSystem.WriteMode writeMode,
TextOutputFormat.TextFormatter<T> formatter)
Deprecated.
Writes a DataSet as text file(s) to the specified location.
|
DataSink<String> |
DataSet.writeAsFormattedText(String filePath,
TextOutputFormat.TextFormatter<T> formatter)
Deprecated.
Writes a DataSet as text file(s) to the specified location.
|
DataSink<T> |
DataSet.writeAsText(String filePath)
Deprecated.
Writes a DataSet as text file(s) to the specified location.
|
DataSink<T> |
DataSet.writeAsText(String filePath,
FileSystem.WriteMode writeMode)
Deprecated.
Writes a DataSet as text file(s) to the specified location.
|
Modifier and Type | Method and Description |
---|---|
DataSink<T> |
DataSink.name(String name)
Deprecated.
|
DataSink<T> |
DataSink.setParallelism(int parallelism)
Deprecated.
Sets the parallelism for this data sink.
|
DataSink<T> |
DataSink.sortLocalOutput(int field,
Order order)
Deprecated.
Use
DataSet.sortPartition(int, Order) instead |
DataSink<T> |
DataSink.sortLocalOutput(String fieldExpression,
Order order)
Deprecated.
Use
DataSet.sortPartition(String, Order) instead |
DataSink<T> |
DataSink.withParameters(Configuration parameters)
Deprecated.
Pass a configuration to the OutputFormat.
|
Modifier and Type | Method and Description |
---|---|
Plan |
OperatorTranslation.translateToPlan(List<DataSink<?>> sinks,
String jobName) |
Constructor and Description |
---|
PlanGenerator(List<DataSink<?>> sinks,
ExecutionConfig config,
int defaultParallelism,
List<Tuple2<String,DistributedCache.DistributedCacheEntry>> cacheFile,
String jobName) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.