Package | Description |
---|---|
org.apache.flink.runtime.io.network | |
org.apache.flink.runtime.io.network.metrics | |
org.apache.flink.runtime.io.network.partition |
Modifier and Type | Method and Description |
---|---|
List<ResultPartition> |
NettyShuffleEnvironment.createResultPartitionWriters(ShuffleIOOwnerContext ownerContext,
List<ResultPartitionDeploymentDescriptor> resultPartitionDeploymentDescriptors) |
Modifier and Type | Method and Description |
---|---|
static void |
NettyShuffleMetricFactory.registerOutputMetrics(boolean isDetailedMetrics,
MetricGroup outputGroup,
ResultPartition[] resultPartitions) |
static void |
ResultPartitionMetrics.registerQueueLengthMetrics(MetricGroup parent,
ResultPartition[] partitions) |
Constructor and Description |
---|
OutputBufferPoolUsageGauge(ResultPartition[] resultPartitions) |
OutputBuffersGauge(ResultPartition[] resultPartitions) |
OutputBuffersSizeGauge(ResultPartition[] resultPartitions) |
Modifier and Type | Class and Description |
---|---|
class |
BoundedBlockingResultPartition
A output data result of an individual task (one partition of an intermediate result), produced
and communicated in a batch manner: The result must be produced completely before it can be
consumed.
|
class |
BufferWritingResultPartition
A
ResultPartition which writes buffers directly to ResultSubpartition s. |
class |
PipelinedResultPartition
A result output of a task, pipelined (streamed) to the receivers.
|
class |
SortMergeResultPartition
SortMergeResultPartition appends records and events to DataBuffer and after the
DataBuffer is full, all data in the DataBuffer will be copied and spilled to a
PartitionedFile in subpartition index order sequentially. |
Modifier and Type | Field and Description |
---|---|
protected ResultPartition |
ResultSubpartition.parent
The parent partition this subpartition belongs to.
|
Modifier and Type | Method and Description |
---|---|
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionDeploymentDescriptor desc) |
ResultPartition |
ResultPartitionFactory.create(String taskNameWithSubtaskAndId,
int partitionIndex,
ResultPartitionID id,
ResultPartitionType type,
int numberOfSubpartitions,
int maxParallelism,
SupplierWithException<BufferPool,IOException> bufferPoolFactory) |
Modifier and Type | Method and Description |
---|---|
abstract org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartition |
BoundedBlockingSubpartitionType.create(int index,
ResultPartition parent,
File tempFile,
int readBufferSize,
boolean sslEnabled)
Creates BoundedBlockingSubpartition of this type.
|
void |
ResultPartitionManager.registerResultPartition(ResultPartition partition) |
Constructor and Description |
---|
ResultSubpartition(int index,
ResultPartition parent) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.