T - @Public public class DataSink<T> extends Object
| Constructor and Description | 
|---|
| DataSink(DataSet<T> data,
        org.apache.flink.api.common.io.OutputFormat<T> format,
        org.apache.flink.api.common.typeinfo.TypeInformation<T> type) | 
| Modifier and Type | Method and Description | 
|---|---|
| DataSet<T> | getDataSet() | 
| org.apache.flink.api.common.io.OutputFormat<T> | getFormat() | 
| org.apache.flink.api.common.operators.ResourceSpec | getMinResources()Returns the minimum resources of this data sink. | 
| int | getParallelism()Returns the parallelism of this data sink. | 
| org.apache.flink.configuration.Configuration | getParameters() | 
| org.apache.flink.api.common.operators.ResourceSpec | getPreferredResources()Returns the preferred resources of this data sink. | 
| org.apache.flink.api.common.typeinfo.TypeInformation<T> | getType() | 
| DataSink<T> | name(String name) | 
| DataSink<T> | setParallelism(int parallelism)Sets the parallelism for this data sink. | 
| DataSink<T> | sortLocalOutput(int field,
               org.apache.flink.api.common.operators.Order order)Deprecated. 
 Use  DataSet.sortPartition(int, Order)instead | 
| DataSink<T> | sortLocalOutput(String fieldExpression,
               org.apache.flink.api.common.operators.Order order)Deprecated. 
 Use  DataSet.sortPartition(String, Order)instead | 
| String | toString() | 
| protected org.apache.flink.api.common.operators.GenericDataSinkBase<T> | translateToDataFlow(org.apache.flink.api.common.operators.Operator<T> input) | 
| DataSink<T> | withParameters(org.apache.flink.configuration.Configuration parameters)Pass a configuration to the OutputFormat. | 
@Internal public org.apache.flink.api.common.io.OutputFormat<T> getFormat()
@Internal public org.apache.flink.api.common.typeinfo.TypeInformation<T> getType()
public DataSink<T> withParameters(org.apache.flink.configuration.Configuration parameters)
parameters - Configuration parameters@Deprecated @PublicEvolving public DataSink<T> sortLocalOutput(int field, org.apache.flink.api.common.operators.Order order)
DataSet.sortPartition(int, Order) insteadTuple data set on the
 specified field in the specified Order before it is emitted by the output format.
 Note: Only tuple data sets can be sorted using integer field indices.
The tuple data set can be sorted on multiple fields in different orders by chaining sortLocalOutput(int, Order) calls.
field - The Tuple field on which the data set is locally sorted.order - The Order in which the specified Tuple field is locally sorted.Tuple, 
Order@Deprecated @PublicEvolving public DataSink<T> sortLocalOutput(String fieldExpression, org.apache.flink.api.common.operators.Order order)
DataSet.sortPartition(String, Order) insteadOrder before it is emitted by the output format.
 Note: Non-composite types can only be sorted on the full element which is specified by a wildcard expression ("*" or "_").
Data sets of composite types (Tuple or Pojo) can be sorted on multiple fields in different
 orders by chaining sortLocalOutput(String, Order) calls.
fieldExpression - The field expression for the field(s) on which the data set is locally
     sorted.order - The Order in which the specified field(s) are locally sorted.Orderpublic org.apache.flink.configuration.Configuration getParameters()
protected org.apache.flink.api.common.operators.GenericDataSinkBase<T> translateToDataFlow(org.apache.flink.api.common.operators.Operator<T> input)
public int getParallelism()
public DataSink<T> setParallelism(int parallelism)
parallelism - The parallelism for this data sink. A value equal to ExecutionConfig.PARALLELISM_DEFAULT will use the system default.@PublicEvolving public org.apache.flink.api.common.operators.ResourceSpec getMinResources()
@PublicEvolving public org.apache.flink.api.common.operators.ResourceSpec getPreferredResources()
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.