Class ChunkedByteBuf
- java.lang.Object
-
- org.apache.flink.queryablestate.network.ChunkedByteBuf
-
- All Implemented Interfaces:
org.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
@Internal public class ChunkedByteBuf extends Object implements org.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
AByteBuf
instance to be consumed in chunks byChunkedWriteHandler
, respecting the high and low watermarks.- See Also:
- Low/High Watermarks
-
-
Constructor Summary
Constructors Constructor Description ChunkedByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf buf, int chunkSize)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
boolean
isEndOfInput()
long
length()
long
progress()
org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf
readChunk(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator byteBufAllocator)
org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf
readChunk(org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerContext ctx)
String
toString()
-
-
-
Method Detail
-
isEndOfInput
public boolean isEndOfInput() throws Exception
- Specified by:
isEndOfInput
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
- Throws:
Exception
-
close
public void close() throws Exception
- Specified by:
close
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
- Throws:
Exception
-
readChunk
public org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf readChunk(org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerContext ctx) throws Exception
- Specified by:
readChunk
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
- Throws:
Exception
-
readChunk
public org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf readChunk(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBufAllocator byteBufAllocator) throws Exception
- Specified by:
readChunk
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
- Throws:
Exception
-
length
public long length()
- Specified by:
length
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
-
progress
public long progress()
- Specified by:
progress
in interfaceorg.apache.flink.shaded.netty4.io.netty.handler.stream.ChunkedInput<org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf>
-
-