Package | Description |
---|---|
org.apache.flink.api.java.io | |
org.apache.flink.api.java.operators |
Modifier and Type | Method and Description |
---|---|
SplitDataProperties<T> |
SplitDataProperties.splitsGroupedBy(int... groupFields)
Defines that the data within an input split is grouped on the fields defined by the field positions.
|
SplitDataProperties<T> |
SplitDataProperties.splitsGroupedBy(String groupFields)
Defines that the data within an input split is grouped on the fields defined by the field expressions.
|
SplitDataProperties<T> |
SplitDataProperties.splitsOrderedBy(int[] orderFields,
org.apache.flink.api.common.operators.Order[] orders)
Defines that the data within an input split is sorted on the fields defined by the field positions
in the specified orders.
|
SplitDataProperties<T> |
SplitDataProperties.splitsOrderedBy(String orderFields,
org.apache.flink.api.common.operators.Order[] orders)
Defines that the data within an input split is sorted on the fields defined by the field expressions
in the specified orders.
|
SplitDataProperties<T> |
SplitDataProperties.splitsPartitionedBy(int... partitionFields)
Defines that data is partitioned across input splits on the fields defined by field positions.
|
SplitDataProperties<T> |
SplitDataProperties.splitsPartitionedBy(String partitionFields)
Defines that data is partitioned across input splits on the fields defined by field expressions.
|
SplitDataProperties<T> |
SplitDataProperties.splitsPartitionedBy(String partitionMethodId,
int... partitionFields)
Defines that data is partitioned using a specific partitioning method
across input splits on the fields defined by field positions.
|
SplitDataProperties<T> |
SplitDataProperties.splitsPartitionedBy(String partitionMethodId,
String partitionFields)
Defines that data is partitioned using an identifiable method
across input splits on the fields defined by field expressions.
|
Modifier and Type | Method and Description |
---|---|
SplitDataProperties<OUT> |
DataSource.getSplitDataProperties()
Returns the
SplitDataProperties for the
InputSplit s of this DataSource
for configurations. |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.