T
- The type of the DataSource on which the SplitDataProperties are defined.@PublicEvolving public class SplitDataProperties<T> extends Object implements org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties<T>
InputSplit
generated by the InputFormat
of a DataSource
.
InputSplits are units of input which are distributed among and assigned to parallel data source subtasks.
SplitDataProperties can define that the elements which are generated by the associated InputFormat
are
InputSplit
,
InputFormat
,
DataSource
Modifier and Type | Class and Description |
---|---|
static class |
SplitDataProperties.SourcePartitionerMarker<T>
A custom partitioner to mark compatible split partitionings.
|
Constructor and Description |
---|
SplitDataProperties(DataSource<T> source)
Creates SplitDataProperties for the given data types.
|
SplitDataProperties(org.apache.flink.api.common.typeinfo.TypeInformation<T> type)
Creates SplitDataProperties for the given data types.
|
Modifier and Type | Method and Description |
---|---|
int[] |
getSplitGroupKeys() |
org.apache.flink.api.common.operators.Ordering |
getSplitOrder() |
org.apache.flink.api.common.functions.Partitioner<T> |
getSplitPartitioner() |
int[] |
getSplitPartitionKeys() |
SplitDataProperties<T> |
splitsGroupedBy(int... groupFields)
Defines that the data within an input split is grouped on the fields defined by the field positions.
|
SplitDataProperties<T> |
splitsGroupedBy(String groupFields)
Defines that the data within an input split is grouped on the fields defined by the field expressions.
|
SplitDataProperties<T> |
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> |
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> |
splitsPartitionedBy(int... partitionFields)
Defines that data is partitioned across input splits on the fields defined by field positions.
|
SplitDataProperties<T> |
splitsPartitionedBy(String partitionFields)
Defines that data is partitioned across input splits on the fields defined by field expressions.
|
SplitDataProperties<T> |
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> |
splitsPartitionedBy(String partitionMethodId,
String partitionFields)
Defines that data is partitioned using an identifiable method
across input splits on the fields defined by field expressions.
|
public SplitDataProperties(org.apache.flink.api.common.typeinfo.TypeInformation<T> type)
type
- The data type of the SplitDataProperties.public SplitDataProperties(DataSource<T> source)
source
- The DataSource for which the SplitDataProperties are created.public SplitDataProperties<T> splitsPartitionedBy(int... partitionFields)
partitionFields
- The field positions of the partitioning keys.public SplitDataProperties<T> splitsPartitionedBy(String partitionMethodId, int... partitionFields)
partitionMethodId
- An ID for the method that was used to partition the data across splits.partitionFields
- The field positions of the partitioning keys.public SplitDataProperties<T> splitsPartitionedBy(String partitionFields)
partitionFields
- The field expressions of the partitioning keys.public SplitDataProperties<T> splitsPartitionedBy(String partitionMethodId, String partitionFields)
partitionMethodId
- An ID for the method that was used to partition the data across splits.partitionFields
- The field expressions of the partitioning keys.public SplitDataProperties<T> splitsGroupedBy(int... groupFields)
groupFields
- The field positions of the grouping keys.public SplitDataProperties<T> splitsGroupedBy(String groupFields)
groupFields
- The field expressions of the grouping keys.public SplitDataProperties<T> splitsOrderedBy(int[] orderFields, org.apache.flink.api.common.operators.Order[] orders)
orderFields
- The field positions of the grouping keys.orders
- The orders of the fields.public SplitDataProperties<T> splitsOrderedBy(String orderFields, org.apache.flink.api.common.operators.Order[] orders)
orderFields
- The field expressions of the grouping key.orders
- The orders of the fields.public int[] getSplitPartitionKeys()
getSplitPartitionKeys
in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties<T>
public org.apache.flink.api.common.functions.Partitioner<T> getSplitPartitioner()
getSplitPartitioner
in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties<T>
public int[] getSplitGroupKeys()
getSplitGroupKeys
in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties<T>
public org.apache.flink.api.common.operators.Ordering getSplitOrder()
getSplitOrder
in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties<T>
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.