Modifier and Type | Method and Description |
---|---|
Partitioner<T> |
GenericDataSourceBase.SplitDataProperties.getSplitPartitioner() |
Modifier and Type | Method and Description |
---|---|
abstract <E> void |
Keys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
<E> void |
Keys.SelectorFunctionKeys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
<E> void |
Keys.ExpressionKeys.validateCustomPartitioner(Partitioner<E> partitioner,
TypeInformation<E> typeInfo) |
Modifier and Type | Method and Description |
---|---|
Partitioner<?> |
GroupReduceOperatorBase.getCustomPartitioner() |
Partitioner<?> |
PartitionOperatorBase.getCustomPartitioner() |
Partitioner<?> |
CoGroupOperatorBase.getCustomPartitioner() |
Partitioner<?> |
ReduceOperatorBase.getCustomPartitioner() |
Partitioner<?> |
JoinOperatorBase.getCustomPartitioner() |
Modifier and Type | Method and Description |
---|---|
void |
GroupReduceOperatorBase.setCustomPartitioner(Partitioner<?> customPartitioner) |
void |
PartitionOperatorBase.setCustomPartitioner(Partitioner<?> customPartitioner) |
void |
CoGroupOperatorBase.setCustomPartitioner(Partitioner<?> customPartitioner) |
void |
ReduceOperatorBase.setCustomPartitioner(Partitioner<?> customPartitioner) |
void |
JoinOperatorBase.setCustomPartitioner(Partitioner<?> partitioner) |
Modifier and Type | Method and Description |
---|---|
<K> PartitionOperator<T> |
DataSet.partitionCustom(Partitioner<K> partitioner,
int field)
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
|
<K extends Comparable<K>> |
DataSet.partitionCustom(Partitioner<K> partitioner,
KeySelector<T,K> keyExtractor)
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
|
<K> PartitionOperator<T> |
DataSet.partitionCustom(Partitioner<K> partitioner,
String field)
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
|
Modifier and Type | Class and Description |
---|---|
class |
IdPartitioner
Partitioner that partitions by id.
|
Modifier and Type | Class and Description |
---|---|
static class |
SplitDataProperties.SourcePartitionerMarker<T>
A custom partitioner to mark compatible split partitionings.
|
Modifier and Type | Method and Description |
---|---|
Partitioner<T> |
SplitDataProperties.getSplitPartitioner() |
Modifier and Type | Field and Description |
---|---|
protected Partitioner<?> |
Grouping.customPartitioner |
Modifier and Type | Method and Description |
---|---|
Partitioner<?> |
Grouping.getCustomPartitioner()
Gets the custom partitioner to be used for this grouping, or
null , if none was
defined. |
Partitioner<?> |
PartitionOperator.getCustomPartitioner()
Gets the custom partitioner from this partitioning.
|
Partitioner<?> |
JoinOperator.getPartitioner()
Gets the custom partitioner used by this join, or
null , if none is set. |
Partitioner<?> |
CoGroupOperator.getPartitioner()
Gets the custom partitioner used by this join, or
null , if none is set. |
Partitioner<?> |
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.getPartitioner()
Gets the custom partitioner used by this join, or
null , if none is set. |
Modifier and Type | Method and Description |
---|---|
JoinOperator<I1,I2,OUT> |
JoinOperator.withPartitioner(Partitioner<?> partitioner)
Sets a custom partitioner for this join.
|
CoGroupOperator<I1,I2,OUT> |
CoGroupOperator.withPartitioner(Partitioner<?> partitioner)
Sets a custom partitioner for the CoGroup operation.
|
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction |
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.withPartitioner(Partitioner<?> partitioner)
Sets a custom partitioner for the CoGroup operation.
|
SortedGrouping<T> |
SortedGrouping.withPartitioner(Partitioner<?> partitioner)
Uses a custom partitioner for the grouping.
|
UnsortedGrouping<T> |
UnsortedGrouping.withPartitioner(Partitioner<?> partitioner)
Uses a custom partitioner for the grouping.
|
Constructor and Description |
---|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderFirst,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderSecond,
Partitioner<?> customPartitioner,
String defaultName) |
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
Partitioner<?> customPartitioner,
String defaultName) |
PartitionOperator(DataSet<T> input,
Keys<T> pKeys,
Partitioner<?> customPartitioner,
String partitionLocationName) |
PartitionOperator(DataSet<T> input,
Keys<T> pKeys,
Partitioner<P> customPartitioner,
TypeInformation<P> partitionerTypeInfo,
String partitionLocationName) |
Modifier and Type | Method and Description |
---|---|
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner) |
static <T> TypeInformation<T> |
TypeExtractor.getPartitionerTypes(Partitioner<T> partitioner,
String functionName,
boolean allowMissing) |
Constructor and Description |
---|
PartitionDescriptor(PartitionOperatorBase.PartitionMethod pMethod,
FieldSet pKeys,
Ordering ordering,
Partitioner<?> customPartitioner,
DataDistribution distribution) |
Modifier and Type | Method and Description |
---|---|
Partitioner<?> |
RequestedGlobalProperties.getCustomPartitioner()
Gets the custom partitioner associated with these properties.
|
Partitioner<?> |
GlobalProperties.getCustomPartitioner() |
Modifier and Type | Method and Description |
---|---|
void |
GlobalProperties.setCustomPartitioned(FieldList partitionedFields,
Partitioner<?> partitioner) |
void |
RequestedGlobalProperties.setCustomPartitioned(FieldSet partitionedFields,
Partitioner<?> partitioner)
Sets these properties to request a custom partitioning with the given
Partitioner
instance. |
Modifier and Type | Method and Description |
---|---|
void |
CoGroupDescriptor.setCustomPartitioner(Partitioner<?> customPartitioner) |
void |
AbstractJoinDescriptor.setCustomPartitioner(Partitioner<?> partitioner) |
Constructor and Description |
---|
GroupReduceProperties(FieldSet groupKeys,
Ordering additionalOrderKeys,
Partitioner<?> customPartitioner) |
GroupReduceProperties(FieldSet keys,
Partitioner<?> customPartitioner) |
GroupReduceWithCombineProperties(FieldSet groupKeys,
Ordering additionalOrderKeys,
Partitioner<?> customPartitioner) |
GroupReduceWithCombineProperties(FieldSet groupKeys,
Partitioner<?> customPartitioner) |
ReduceProperties(FieldSet keys,
Partitioner<?> customPartitioner,
DriverStrategy combinerStrategy) |
Modifier and Type | Method and Description |
---|---|
Partitioner<?> |
Channel.getPartitioner() |
Modifier and Type | Method and Description |
---|---|
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
boolean[] sortDirection,
Partitioner<?> partitioner,
DataExchangeMode dataExchangeMode) |
void |
Channel.setShipStrategy(ShipStrategyType strategy,
FieldList keys,
Partitioner<?> partitioner,
DataExchangeMode dataExchangeMode) |
Constructor and Description |
---|
OutputEmitter(ShipStrategyType strategy,
int indexInSubtaskGroup,
TypeComparator<T> comparator,
Partitioner<?> partitioner,
DataDistribution distribution) |
Modifier and Type | Method and Description |
---|---|
Partitioner<?> |
TaskConfig.getOutputPartitioner(int outputNum,
ClassLoader cl) |
Modifier and Type | Method and Description |
---|---|
void |
TaskConfig.setOutputPartitioner(Partitioner<?> partitioner,
int outputNum) |
Modifier and Type | Class and Description |
---|---|
class |
KeyGroupRangePartitioner
A partitioner that selects the target channel based on the key group index.
|
Modifier and Type | Method and Description |
---|---|
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
int field)
Deprecated.
|
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
KeySelector<T,K> keySelector)
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
|
<K> DataStream<T> |
DataStream.partitionCustom(Partitioner<K> partitioner,
String field)
Deprecated.
|
Constructor and Description |
---|
CustomPartitionerWrapper(Partitioner<K> partitioner,
KeySelector<T,K> keySelector) |
Modifier and Type | Method and Description |
---|---|
static <X,K> KeySelector<X,K> |
KeySelectorUtil.getSelectorForOneKey(Keys<X> keys,
Partitioner<K> partitioner,
TypeInformation<X> typeInfo,
ExecutionConfig executionConfig) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.