Buffer.DataType
Constructor and Description |
---|
CompositeBuffer(Buffer.DataType dataType,
int length,
boolean isCompressed) |
CompositeBuffer(BufferHeader header) |
Modifier and Type | Method and Description |
---|---|
void |
addPartialBuffer(Buffer buffer) |
org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf |
asByteBuf() |
Buffer.DataType |
getDataType()
Gets the type of data this buffer represents.
|
Buffer |
getFullBufferData(MemorySegment segment)
Returns the full buffer data in one piece of
MemorySegment . |
int |
getMaxCapacity()
Returns the maximum size of the buffer, i.e. the capacity of the underlying
MemorySegment . |
MemorySegment |
getMemorySegment()
Returns the underlying memory segment.
|
int |
getMemorySegmentOffset()
This method will be removed in the future.
|
ByteBuffer |
getNioBuffer(int index,
int length)
Gets a new
ByteBuffer instance wrapping this buffer's bytes. |
ByteBuffer |
getNioBufferReadable()
Gets a new
ByteBuffer instance wrapping this buffer's readable bytes, i.e. between
Buffer.getReaderIndex() and Buffer.getSize() . |
int |
getReaderIndex()
Returns the reader index of this buffer.
|
BufferRecycler |
getRecycler()
Gets the buffer's recycler.
|
int |
getSize()
Returns the size of the written data, i.e. the writer index, of this buffer.
|
boolean |
isBuffer()
Returns whether this buffer represents a buffer or an event.
|
boolean |
isCompressed() |
boolean |
isRecycled()
Returns whether this buffer has been recycled or not.
|
int |
missingLength() |
int |
numPartialBuffers() |
int |
readableBytes()
Returns the number of readable bytes (same as
Buffer.getSize() - Buffer.getReaderIndex() ). |
Buffer |
readOnlySlice()
Returns a read-only slice of this buffer's readable bytes, i.e. between
Buffer.getReaderIndex() and Buffer.getSize() . |
Buffer |
readOnlySlice(int index,
int length)
Returns a read-only slice of this buffer.
|
void |
recycleBuffer()
Releases this buffer once, i.e. reduces the reference count and recycles the buffer if the
reference count reaches 0.
|
int |
refCnt()
The current reference counter.
|
Buffer |
retainBuffer()
Retains this buffer for further use, increasing the reference counter by 1.
|
void |
setAllocator(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator allocator)
Sets the buffer allocator for use in netty.
|
void |
setCompressed(boolean isCompressed)
Tags the buffer as compressed or uncompressed.
|
void |
setDataType(Buffer.DataType dataType)
Sets the type of data this buffer represents.
|
void |
setReaderIndex(int readerIndex)
Sets the reader index of this buffer.
|
void |
setRecycler(BufferRecycler bufferRecycler)
Sets the buffer's recycler.
|
void |
setSize(int writerIndex)
Sets the size of the written data, i.e. the writer index, of this buffer.
|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
toDebugString
public CompositeBuffer(Buffer.DataType dataType, int length, boolean isCompressed)
public CompositeBuffer(BufferHeader header)
public boolean isBuffer()
Buffer
public void recycleBuffer()
Buffer
recycleBuffer
in interface Buffer
Buffer.retainBuffer()
public Buffer retainBuffer()
Buffer
retainBuffer
in interface Buffer
Buffer.recycleBuffer()
public int getSize()
Buffer
This is where writable bytes start in the backing memory segment.
getSize
in interface Buffer
MemorySegment
(inclusive))public int readableBytes()
Buffer
Buffer.getSize()
- Buffer.getReaderIndex()
).readableBytes
in interface Buffer
public void setAllocator(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator allocator)
Buffer
setAllocator
in interface Buffer
allocator
- netty buffer allocatorpublic org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf asByteBuf()
public boolean isCompressed()
isCompressed
in interface Buffer
public Buffer.DataType getDataType()
Buffer
getDataType
in interface Buffer
public int numPartialBuffers()
public Buffer getFullBufferData(MemorySegment segment)
MemorySegment
. If there is multiple
partial buffers, the partial data will be copied to the given target MemorySegment
.public void addPartialBuffer(Buffer buffer)
public int missingLength()
public MemorySegment getMemorySegment()
Buffer
Buffer.getMemorySegmentOffset()
.
This method will be removed in the future. For writing use BufferBuilder
.
getMemorySegment
in interface Buffer
public int getMemorySegmentOffset()
Buffer
BufferBuilder
.getMemorySegmentOffset
in interface Buffer
Buffer
's data start in the underlying
memory segment.public BufferRecycler getRecycler()
Buffer
getRecycler
in interface Buffer
public void setRecycler(BufferRecycler bufferRecycler)
Buffer
Note that updating the recycler is an unsafe operation and this method cannot guarantee thread safety. It is important for the caller to fully understand the consequences of calling this method. Incorrectly updating the buffer recycler can result in a leak of the buffer due to using a wrong recycler to recycle buffer. Therefore, be careful when calling this method.
setRecycler
in interface Buffer
bufferRecycler
- the new buffer recyclerpublic boolean isRecycled()
Buffer
isRecycled
in interface Buffer
public Buffer readOnlySlice()
Buffer
Buffer.getReaderIndex()
and Buffer.getSize()
.
Reader and writer indices as well as markers are not shared. Reference counters are shared
but the slice is not retained
automatically.
readOnlySlice
in interface Buffer
public Buffer readOnlySlice(int index, int length)
Buffer
Reader and writer indices as well as markers are not shared. Reference counters are shared
but the slice is not retained
automatically.
readOnlySlice
in interface Buffer
index
- the index to start fromlength
- the length of the slicepublic int getMaxCapacity()
Buffer
MemorySegment
.getMaxCapacity
in interface Buffer
public int getReaderIndex()
Buffer
This is where readable (unconsumed) bytes start in the backing memory segment.
getReaderIndex
in interface Buffer
MemorySegment
(inclusive))public void setReaderIndex(int readerIndex)
Buffer
setReaderIndex
in interface Buffer
public void setSize(int writerIndex)
Buffer
public ByteBuffer getNioBufferReadable()
Buffer
ByteBuffer
instance wrapping this buffer's readable bytes, i.e. between
Buffer.getReaderIndex()
and Buffer.getSize()
.
Please note that neither index is updated by the returned buffer.
getNioBufferReadable
in interface Buffer
public ByteBuffer getNioBuffer(int index, int length)
Buffer
ByteBuffer
instance wrapping this buffer's bytes.
Please note that neither read nor write index are updated by the returned buffer.
getNioBuffer
in interface Buffer
Buffer.getNioBufferReadable()
public void setCompressed(boolean isCompressed)
Buffer
setCompressed
in interface Buffer
public void setDataType(Buffer.DataType dataType)
Buffer
setDataType
in interface Buffer
public int refCnt()
Buffer
Buffer.retainBuffer()
and decreased with Buffer.recycleBuffer()
.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.