Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
InputGateDeploymentDescriptor.getConsumedPartitionType()
Returns the type of this input channel's consumed result partition.
|
ResultPartitionType |
ResultPartitionDeploymentDescriptor.getPartitionType() |
Constructor and Description |
---|
InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
ShuffleDescriptor[] inputChannels) |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
IntermediateResultPartition.getResultType() |
ResultPartitionType |
IntermediateResult.getResultType() |
Constructor and Description |
---|
IntermediateResult(IntermediateDataSetID id,
ExecutionJobVertex producer,
int numParallelProducers,
ResultPartitionType resultType) |
Modifier and Type | Field and Description |
---|---|
protected ResultPartitionType |
ResultPartition.partitionType
Type of this partition.
|
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
ResultPartition.getPartitionType()
Returns the type of this result partition.
|
static ResultPartitionType |
ResultPartitionType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ResultPartitionType[] |
ResultPartitionType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionID id,
ResultPartitionType type,
int numberOfSubpartitions,
int maxParallelism,
FunctionWithException<BufferPoolOwner,BufferPool,IOException> bufferPoolFactory) |
Constructor and Description |
---|
ResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
ResultSubpartition[] subpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
FunctionWithException<BufferPoolOwner,BufferPool,IOException> bufferPoolFactory) |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
SingleInputGate.getConsumedPartitionType()
Returns the type of this input channel's consumed result partition.
|
Constructor and Description |
---|
SingleInputGate(String owningTaskName,
int gateIndex,
IntermediateDataSetID consumedResultId,
ResultPartitionType consumedPartitionType,
int consumedSubpartitionIndex,
int numberOfInputChannels,
PartitionProducerStateProvider partitionProducerStateProvider,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
BufferDecompressor bufferDecompressor,
MemorySegmentProvider memorySegmentProvider) |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
IntermediateDataSet.getResultType() |
Modifier and Type | Method and Description |
---|---|
JobEdge |
JobVertex.connectNewDataSetAsInput(JobVertex input,
DistributionPattern distPattern,
ResultPartitionType partitionType) |
IntermediateDataSet |
JobVertex.createAndAddResultDataSet(IntermediateDataSetID id,
ResultPartitionType partitionType) |
IntermediateDataSet |
JobVertex.createAndAddResultDataSet(ResultPartitionType partitionType) |
Constructor and Description |
---|
IntermediateDataSet(IntermediateDataSetID id,
ResultPartitionType resultType,
JobVertex producer) |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
DefaultLogicalResult.getResultType() |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
PartitionDescriptor.getPartitionType() |
Constructor and Description |
---|
PartitionDescriptor(IntermediateDataSetID resultId,
int totalNumberOfPartitions,
IntermediateResultPartitionID partitionId,
ResultPartitionType partitionType,
int numberOfSubpartitions,
int connectionIndex) |
Modifier and Type | Method and Description |
---|---|
ResultPartitionType |
Result.getResultType() |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.