Modifier and Type | Method and Description |
---|---|
boolean |
BufferFileChannelReader.readBufferFromFileChannel(Buffer buffer)
Reads data from the object's file channel into the given buffer.
|
void |
AsynchronousBufferFileReader.readInto(Buffer buffer) |
void |
SynchronousBufferFileReader.readInto(Buffer buffer) |
void |
BufferFileReader.readInto(Buffer buffer) |
void |
AsynchronousBufferFileWriter.writeBlock(Buffer buffer)
Writes the given block asynchronously.
|
Modifier and Type | Method and Description |
---|---|
abstract BufferFileReader |
IOManager.createBufferFileReader(FileIOChannel.ID channelID,
RequestDoneCallback<Buffer> callback) |
BufferFileReader |
IOManagerAsync.createBufferFileReader(FileIOChannel.ID channelID,
RequestDoneCallback<Buffer> callback) |
Constructor and Description |
---|
AsynchronousBufferFileReader(FileIOChannel.ID channelID,
RequestQueue<org.apache.flink.runtime.io.disk.iomanager.ReadRequest> requestQueue,
RequestDoneCallback<Buffer> callback) |
Modifier and Type | Method and Description |
---|---|
Buffer |
RecordDeserializer.getCurrentBuffer() |
Buffer |
SpillingAdaptiveSpanningRecordDeserializer.getCurrentBuffer() |
static Buffer |
EventSerializer.toBuffer(AbstractEvent event) |
Modifier and Type | Method and Description |
---|---|
static AbstractEvent |
EventSerializer.fromBuffer(Buffer buffer,
ClassLoader classLoader) |
static boolean |
EventSerializer.isEvent(Buffer buffer,
Class<?> eventClass)
Identifies whether the given buffer encodes the given event.
|
void |
RecordDeserializer.setNextBuffer(Buffer buffer) |
void |
SpillingAdaptiveSpanningRecordDeserializer.setNextBuffer(Buffer buffer) |
Modifier and Type | Class and Description |
---|---|
class |
NetworkBuffer
Wrapper for pooled
MemorySegment instances. |
class |
ReadOnlySlicedNetworkBuffer
Minimal best-effort read-only sliced
Buffer implementation wrapping a
NetworkBuffer 's sub-region based on io.netty.buffer.SlicedByteBuf and
io.netty.buffer.ReadOnlyByteBuf. |
Modifier and Type | Method and Description |
---|---|
Buffer |
BufferConsumer.build() |
Buffer |
Buffer.readOnlySlice()
Returns a read-only slice of this buffer's readable bytes, i.e.
|
Buffer |
Buffer.readOnlySlice(int index,
int length)
Returns a read-only slice of this buffer.
|
Buffer |
BufferProvider.requestBuffer()
Returns a
Buffer instance from the buffer provider, if one is available. |
Buffer |
BufferProvider.requestBufferBlocking()
Returns a
Buffer instance from the buffer provider. |
Buffer |
Buffer.retainBuffer()
Retains this buffer for further use, increasing the reference counter by 1.
|
Modifier and Type | Method and Description |
---|---|
boolean |
BufferListener.notifyBufferAvailable(Buffer buffer)
Notification callback if a buffer is recycled and becomes available in buffer pool.
|
Modifier and Type | Method and Description |
---|---|
Buffer |
ResultSubpartition.BufferAndBacklog.buffer() |
Modifier and Type | Method and Description |
---|---|
int |
ResultSubpartition.decreaseBuffersInBacklog(Buffer buffer)
Decreases the number of non-event buffers by one after fetching a non-event
buffer from this subpartition (for access by the subpartition views).
|
protected void |
ResultSubpartition.updateStatistics(Buffer buffer) |
Constructor and Description |
---|
BufferAndBacklog(Buffer buffer,
boolean isMoreAvailable,
int buffersInBacklog,
boolean nextBufferIsEvent) |
Modifier and Type | Method and Description |
---|---|
Buffer |
InputChannel.BufferAndAvailability.buffer() |
Buffer |
BufferOrEvent.getBuffer() |
Buffer |
RemoteInputChannel.requestBuffer()
Requests buffer from input channel directly for receiving network data.
|
Modifier and Type | Method and Description |
---|---|
boolean |
RemoteInputChannel.notifyBufferAvailable(Buffer buffer)
The Buffer pool notifies this channel of an available floating buffer.
|
void |
RemoteInputChannel.onBuffer(Buffer buffer,
int sequenceNumber,
int backlog) |
Constructor and Description |
---|
BufferAndAvailability(Buffer buffer,
boolean moreAvailable,
int buffersInBacklog) |
BufferOrEvent(Buffer buffer,
int channelIndex) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.