public class TieredResultPartition extends ResultPartition
TieredResultPartition
appends records and events to the tiered storage, which supports
the upstream dynamically switches storage tier for writing shuffle data, and the downstream will
read data from the relevant tier.AvailabilityProvider.AvailabilityHelper
bufferCompressor, bufferPool, LOG, numBuffersOut, numBytesOut, numSubpartitions, partitionManager, partitionType, resultPartitionBytes
AVAILABLE
Constructor and Description |
---|
TieredResultPartition(String owningTaskName,
int partitionIndex,
ResultPartitionID partitionId,
ResultPartitionType partitionType,
int numSubpartitions,
int numTargetKeyGroups,
ResultPartitionManager partitionManager,
BufferCompressor bufferCompressor,
SupplierWithException<BufferPool,IOException> bufferPoolFactory,
TieredStorageProducerClient tieredStorageProducerClient,
TieredStorageResourceRegistry tieredStorageResourceRegistry,
TieredStorageNettyServiceImpl nettyService,
List<TieredStorageMemorySpec> tieredStorageMemorySpecs,
TieredStorageMemoryManager storageMemoryManager) |
Modifier and Type | Method and Description |
---|---|
void |
abortCheckpoint(long checkpointId,
CheckpointException cause)
Abort the checkpoint.
|
void |
alignedBarrierTimeout(long checkpointId)
Timeout the aligned barrier to unaligned barrier.
|
void |
broadcastEvent(AbstractEvent event,
boolean isPriorityEvent)
Writes the given
AbstractEvent to all subpartitions. |
void |
broadcastRecord(ByteBuffer record)
Writes the given serialized record to all subpartitions.
|
void |
close()
Closes the partition writer which releases the allocated resource, for example the buffer
pool.
|
protected ResultSubpartitionView |
createSubpartitionView(int subpartitionId,
BufferAvailabilityListener availabilityListener)
Returns a reader for the subpartition with the given index.
|
void |
emitRecord(ByteBuffer record,
int consumerId)
Writes the given serialized record to the target subpartition.
|
void |
finish()
Finishes the result partition.
|
void |
flush(int subpartitionIndex)
Manually trigger the consumption of data from the given subpartitions.
|
void |
flushAll()
Manually trigger the consumption of data from all subpartitions.
|
CompletableFuture<Void> |
getAllDataProcessedFuture()
Gets the future indicating whether all the records has been processed by the downstream
tasks.
|
CompletableFuture<?> |
getAvailableFuture() |
int |
getNumberOfQueuedBuffers()
Returns the total number of queued buffers of all subpartitions.
|
int |
getNumberOfQueuedBuffers(int targetSubpartition)
Returns the number of queued buffers of the given target subpartition.
|
long |
getSizeOfQueuedBuffersUnsafe()
Returns the total size in bytes of queued buffers of all subpartitions.
|
void |
notifyEndOfData(StopMode mode)
Notifies the downstream tasks that this
ResultPartitionWriter have emitted all the
user records. |
void |
onSubpartitionAllDataProcessed(int subpartition)
The subpartition notifies that the corresponding downstream task have processed all the user
records.
|
protected void |
releaseInternal()
Releases all produced data including both those stored in memory and persisted on disk.
|
void |
setMetricGroup(TaskIOMetricGroup metrics)
Sets the metric group for the
ResultPartitionWriter . |
protected void |
setupInternal()
Do the subclass's own setup operation.
|
canBeCompressed, checkInProduceState, createSubpartitionView, fail, getBufferPool, getFailureCause, getNumberOfSubpartitions, getNumTargetKeyGroups, getOwningTaskName, getPartitionId, getPartitionIndex, getPartitionManager, getPartitionType, getResultPartitionBytes, isFinished, isNumberOfPartitionConsumerUndefined, isNumberOfPartitionConsumerUndefined, isReleased, release, release, setMaxOverdraftBuffersPerGate, setup, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
and, isApproximatelyAvailable, isAvailable, or
public TieredResultPartition(String owningTaskName, int partitionIndex, ResultPartitionID partitionId, ResultPartitionType partitionType, int numSubpartitions, int numTargetKeyGroups, ResultPartitionManager partitionManager, @Nullable BufferCompressor bufferCompressor, SupplierWithException<BufferPool,IOException> bufferPoolFactory, TieredStorageProducerClient tieredStorageProducerClient, TieredStorageResourceRegistry tieredStorageResourceRegistry, TieredStorageNettyServiceImpl nettyService, List<TieredStorageMemorySpec> tieredStorageMemorySpecs, TieredStorageMemoryManager storageMemoryManager)
protected void setupInternal() throws IOException
ResultPartition
setupInternal
in class ResultPartition
IOException
public void setMetricGroup(TaskIOMetricGroup metrics)
ResultPartitionWriter
ResultPartitionWriter
.setMetricGroup
in interface ResultPartitionWriter
setMetricGroup
in class ResultPartition
public void emitRecord(ByteBuffer record, int consumerId) throws IOException
ResultPartitionWriter
IOException
public void broadcastRecord(ByteBuffer record) throws IOException
ResultPartitionWriter
IOException
public void broadcastEvent(AbstractEvent event, boolean isPriorityEvent) throws IOException
ResultPartitionWriter
AbstractEvent
to all subpartitions.IOException
protected ResultSubpartitionView createSubpartitionView(int subpartitionId, BufferAvailabilityListener availabilityListener) throws IOException
ResultPartition
Given that the function to merge outputs from multiple subpartition views is supported
uniformly in UnionResultSubpartitionView
, subclasses of ResultPartition
only
needs to take care of creating subpartition view for a single subpartition.
createSubpartitionView
in class ResultPartition
IOException
public void finish() throws IOException
ResultPartition
After this operation, it is not possible to add further data to the result partition.
For BLOCKING results, this will trigger the deployment of consuming tasks.
finish
in interface ResultPartitionWriter
finish
in class ResultPartition
IOException
public void close()
ResultPartitionWriter
close
in interface AutoCloseable
close
in interface ResultPartitionWriter
close
in class ResultPartition
protected void releaseInternal()
ResultPartition
releaseInternal
in class ResultPartition
public void notifyEndOfData(StopMode mode) throws IOException
ResultPartitionWriter
ResultPartitionWriter
have emitted all the
user records.notifyEndOfData
in interface ResultPartitionWriter
notifyEndOfData
in class ResultPartition
mode
- tells if we should flush all records or not (it is false in case of
stop-with-savepoint (--no-drain))IOException
public CompletableFuture<?> getAvailableFuture()
getAvailableFuture
in interface AvailabilityProvider
getAvailableFuture
in class ResultPartition
public void alignedBarrierTimeout(long checkpointId) throws IOException
ResultPartitionWriter
IOException
public void abortCheckpoint(long checkpointId, CheckpointException cause)
ResultPartitionWriter
public void flushAll()
ResultPartitionWriter
public void flush(int subpartitionIndex)
ResultPartitionWriter
public CompletableFuture<Void> getAllDataProcessedFuture()
ResultPartitionWriter
getAllDataProcessedFuture
in interface ResultPartitionWriter
getAllDataProcessedFuture
in class ResultPartition
public void onSubpartitionAllDataProcessed(int subpartition)
ResultPartition
onSubpartitionAllDataProcessed
in class ResultPartition
subpartition
- The index of the subpartition sending the notification.EndOfData
public int getNumberOfQueuedBuffers()
ResultPartition
getNumberOfQueuedBuffers
in class ResultPartition
public long getSizeOfQueuedBuffersUnsafe()
ResultPartition
getSizeOfQueuedBuffersUnsafe
in class ResultPartition
public int getNumberOfQueuedBuffers(int targetSubpartition)
ResultPartition
getNumberOfQueuedBuffers
in class ResultPartition
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.