Modifier and Type | Method and Description |
---|---|
Buffer.DataType |
NetworkBuffer.getDataType() |
Buffer.DataType |
CompositeBuffer.getDataType() |
Buffer.DataType |
ReadOnlySlicedNetworkBuffer.getDataType() |
Buffer.DataType |
BufferBuilder.getDataType()
Gets the data type of the internal buffer.
|
Buffer.DataType |
Buffer.getDataType()
Gets the type of data this buffer represents.
|
Buffer.DataType |
BufferHeader.getDataType() |
Buffer.DataType |
BufferConsumer.getDataType() |
Buffer.DataType |
FileRegionBuffer.getDataType() |
static Buffer.DataType |
Buffer.DataType.getDataType(AbstractEvent event,
boolean hasPriority) |
static Buffer.DataType |
Buffer.DataType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static Buffer.DataType[] |
Buffer.DataType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
void |
NetworkBuffer.setDataType(Buffer.DataType dataType) |
void |
CompositeBuffer.setDataType(Buffer.DataType dataType) |
void |
ReadOnlySlicedNetworkBuffer.setDataType(Buffer.DataType dataType) |
void |
BufferBuilder.setDataType(Buffer.DataType dataType)
Sets the data type of the internal buffer.
|
void |
Buffer.setDataType(Buffer.DataType dataType)
Sets the type of data this buffer represents.
|
void |
FileRegionBuffer.setDataType(Buffer.DataType dataType) |
Constructor and Description |
---|
BufferHeader(boolean isCompressed,
int length,
Buffer.DataType dataType) |
CompositeBuffer(Buffer.DataType dataType,
int length,
boolean isCompressed) |
FileRegionBuffer(FileChannel fileChannel,
long fileChannelPosition,
int bufferSize,
Buffer.DataType dataType,
boolean isCompressed) |
NetworkBuffer(MemorySegment memorySegment,
BufferRecycler recycler,
Buffer.DataType dataType)
Creates a new buffer instance backed by the given memorySegment with 0 for
the readerIndex and writerIndex.
|
NetworkBuffer(MemorySegment memorySegment,
BufferRecycler recycler,
Buffer.DataType dataType,
boolean isCompressed,
int size)
Creates a new buffer instance backed by the given memorySegment with 0 for
the readerIndex and size as writerIndex.
|
NetworkBuffer(MemorySegment memorySegment,
BufferRecycler recycler,
Buffer.DataType dataType,
int size)
Creates a new buffer instance backed by the given memorySegment with 0 for
the readerIndex and size as writerIndex.
|
Modifier and Type | Method and Description |
---|---|
Buffer.DataType |
ResultSubpartition.BufferAndBacklog.getNextDataType() |
Modifier and Type | Method and Description |
---|---|
boolean |
DataBuffer.append(ByteBuffer source,
int targetSubpartition,
Buffer.DataType dataType)
Appends data of the specified subpartition to this
DataBuffer and returns true if
this DataBuffer is full. |
boolean |
SortBuffer.append(ByteBuffer source,
int targetSubpartition,
Buffer.DataType dataType)
No partial record will be written to this
SortBasedDataBuffer , which means that
either all data of target record will be written or nothing will be written. |
boolean |
HashBasedDataBuffer.append(ByteBuffer source,
int targetSubpartition,
Buffer.DataType dataType)
Partial data of the target record can be written if this
HashBasedDataBuffer is full. |
static ResultSubpartition.BufferAndBacklog |
ResultSubpartition.BufferAndBacklog.fromBufferAndLookahead(Buffer current,
Buffer.DataType nextDataType,
int backlog,
int sequenceNumber) |
Constructor and Description |
---|
BufferAndBacklog(Buffer buffer,
int buffersInBacklog,
Buffer.DataType nextDataType,
int sequenceNumber) |
Constructor and Description |
---|
BufferAndAvailability(Buffer buffer,
Buffer.DataType nextDataType,
int buffersInBacklog,
int sequenceNumber) |
Modifier and Type | Method and Description |
---|---|
Buffer.DataType |
HsSubpartitionFileReaderImpl.BufferIndexOrError.getDataType() |
Buffer.DataType |
HsSubpartitionConsumerMemoryDataManager.peekNextToConsumeDataType(int nextToConsumeIndex,
Collection<Buffer> buffersToRecycle)
Check whether the head of
HsSubpartitionConsumerMemoryDataManager.unConsumedBuffers is the buffer to be consumed next time. |
Buffer.DataType |
HsSubpartitionFileReaderImpl.peekNextToConsumeDataType(int nextBufferToConsume,
Collection<Buffer> buffersToRecycle) |
Buffer.DataType |
HsDataView.peekNextToConsumeDataType(int nextBufferToConsume,
Collection<Buffer> buffersToRecycle)
Get dataType of next buffer to consume.
|
Modifier and Type | Method and Description |
---|---|
void |
HsSubpartitionMemoryDataManager.append(ByteBuffer record,
Buffer.DataType dataType)
Append record to
HsSubpartitionMemoryDataManager . |
void |
HsMemoryDataManager.append(ByteBuffer record,
int targetChannel,
Buffer.DataType dataType)
Append record to
HsMemoryDataManager , It will be managed by HsSubpartitionMemoryDataManager witch it belongs to. |
Modifier and Type | Method and Description |
---|---|
void |
HashSubpartitionBufferAccumulator.append(ByteBuffer record,
Buffer.DataType dataType) |
void |
HashBufferAccumulator.receive(ByteBuffer record,
TieredStorageSubpartitionId subpartitionId,
Buffer.DataType dataType,
boolean isBroadcast) |
void |
BufferAccumulator.receive(ByteBuffer record,
TieredStorageSubpartitionId subpartitionId,
Buffer.DataType dataType,
boolean isBroadcast)
Receives the records from tiered store producer, these records will be accumulated and
transformed into finished buffers.
|
void |
SortBufferAccumulator.receive(ByteBuffer record,
TieredStorageSubpartitionId subpartitionId,
Buffer.DataType dataType,
boolean isBroadcast) |
void |
TieredStorageProducerClient.write(ByteBuffer record,
TieredStorageSubpartitionId subpartitionId,
Buffer.DataType dataType,
boolean isBroadcast)
Write records to the producer client.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.