Package | Description |
---|---|
reactor.io |
Buffer-handling and other IO-related components.
|
reactor.io.buffer | |
reactor.io.codec |
Components to handle encoding and decoding of objects into
Buffers . |
reactor.io.codec.compress | |
reactor.io.codec.json |
Encoding and decoding using the JSON format.
|
reactor.io.net |
Reactive network components are located in this package scope implementing the following exposed contract:
A
ReactorPeer NetServer/NetClient is a Publisher of
ReactorChannel that are themselves Publisher of input data. |
reactor.io.net.codec.syslog |
Decoding using the syslog format.
|
reactor.io.net.http |
Components for writing HTTP-based clients and servers using Reactor abstractions.
|
reactor.io.net.impl.netty |
Implementations of the various TCP abstractions based on Netty.
|
reactor.io.net.impl.netty.http | |
reactor.io.net.impl.netty.tcp | |
reactor.io.net.impl.netty.udp | |
reactor.io.net.impl.zmq | |
reactor.io.net.impl.zmq.tcp | |
reactor.io.net.tcp |
Components for writing TCP-based clients and servers using Reactor abstractions.
|
reactor.io.net.udp | |
reactor.io.queue |
Queue implementations that provide a persistence strategy for making sure items in the Queue aren't lost. |
reactor.io.queue.spec |
Specs provide a simple fluent DSL for creating
PersistentQueues by
specifying common options. |
reactor.rx.stream.io |
Stream implementations that provide for IO access, for instance read/read-write persisting streams |
Modifier and Type | Method and Description |
---|---|
static org.reactivestreams.Publisher<Buffer> |
IO.read(ReadableByteChannel channel)
Transform a
ReadableByteChannel into a Publisher of Buffer with a max chunk size of
Buffer.SMALL_BUFFER_SIZE . |
static org.reactivestreams.Publisher<Buffer> |
IO.read(ReadableByteChannel channel,
int chunkSize)
|
static org.reactivestreams.Publisher<Buffer> |
IO.readFile(Path path)
|
static org.reactivestreams.Publisher<Buffer> |
IO.readFile(Path path,
int chunkSize)
|
static org.reactivestreams.Publisher<Buffer> |
IO.readFile(String path)
|
static org.reactivestreams.Publisher<Buffer> |
IO.readFile(String path,
int chunkSize)
|
Modifier and Type | Field and Description |
---|---|
static Buffer |
Buffer.DELIMITING_BUFFER
A delimiting buffer is sent to
BufferCodec and other components to signal the end of a sequence of Buffer. |
Modifier and Type | Method and Description |
---|---|
Buffer |
Buffer.append(Buffer... buffers)
Append the given
Buffer to this Buffer. |
Buffer |
Buffer.append(byte b)
Append the given
byte to this Buffer. |
Buffer |
Buffer.append(byte[] b)
Append the given
byte[] to this Buffer. |
Buffer |
Buffer.append(byte[] b,
int start,
int len)
Append the given
byte[] to this Buffer, starting at the given index and continuing for the
given
length. |
Buffer |
Buffer.append(ByteBuffer... buffers)
Append the given
ByteBuffer to this Buffer. |
Buffer |
Buffer.append(char c)
Append the given
char to this Buffer. |
Buffer |
Buffer.append(int i)
Append the given
int to this Buffer. |
Buffer |
Buffer.append(long l)
Append the given
long to this Buffer. |
Buffer |
Buffer.append(short s)
Append the given
short to this Buffer. |
Buffer |
Buffer.append(String s)
Append the given String to this Buffer.
|
Buffer |
Buffer.clear()
Clear the internal
ByteBuffer by setting the Buffer.position(int) to 0 and the limit to the
current capacity. |
Buffer |
Buffer.compact()
Compact the underlying
ByteBuffer . |
Buffer |
Buffer.copy()
|
Buffer |
Buffer.duplicate()
|
Buffer |
Buffer.flip()
Flip this Buffer.
|
Buffer |
Buffer.View.get() |
Buffer |
Buffer.limit(int limit)
Sets this buffer's limit.
|
Buffer |
Buffer.position(int pos)
Sets this buffer's position.
|
Buffer |
Buffer.prepend(Buffer b)
Prepend the given
Buffer to this Buffer. |
Buffer |
Buffer.prepend(byte b)
Prepend the given
byte to this Buffer. |
Buffer |
Buffer.prepend(byte[] bytes)
Prepend the given
byte[] array to this Buffer. |
Buffer |
Buffer.prepend(ByteBuffer b)
Prepend the given
ByteBuffer to this Buffer. |
Buffer |
Buffer.prepend(char c)
Prepend the given
char to this existing Buffer. |
Buffer |
Buffer.prepend(int i)
Prepend the given
int to this Buffer. |
Buffer |
Buffer.prepend(long l)
Prepend the given
long to this Buffer. |
Buffer |
Buffer.prepend(short s)
Prepend the given
short to this Buffer. |
Buffer |
Buffer.prepend(String s)
Prepend the given
String to this Buffer. |
Buffer |
Buffer.read(byte[] b)
Read at least
b.length bytes from the underlying ByteBuffer . |
Buffer |
Buffer.reset()
Reset the buffer to the previously-saved position and limit.
|
Buffer |
Buffer.rewind()
Rewind this Buffer to the beginning.
|
Buffer |
Buffer.rewind(int len)
Rewinds this buffer by
len bytes. |
Buffer |
Buffer.skip(int len)
Skips
len bytes. |
Buffer |
Buffer.slice(int start,
int len)
Create a copy of the given range.
|
static Buffer |
Buffer.wrap(byte[] bytes)
Convenience method to create a new, fixed-length Buffer and putting the given byte array into the
buffer.
|
static Buffer |
Buffer.wrap(String str)
Convenience method to create a new, fixed-length Buffer from the given String.
|
static Buffer |
Buffer.wrap(String str,
boolean fixed)
Convenience method to create a new Buffer from the given String and optionally specify whether the new
Buffer should be a fixed length or not.
|
Modifier and Type | Method and Description |
---|---|
Reference<Buffer> |
BufferAllocator.allocate() |
List<Reference<Buffer>> |
BufferAllocator.allocateBatch(int size) |
Modifier and Type | Method and Description |
---|---|
Buffer |
Buffer.append(Buffer... buffers)
Append the given
Buffer to this Buffer. |
int |
Buffer.compareTo(Buffer buffer) |
static Integer |
Buffer.parseInt(Buffer b)
Very efficient method for parsing an
Integer from the given Buffer. |
static Integer |
Buffer.parseInt(Buffer b,
int start,
int end)
Very efficient method for parsing an
Integer from the given Buffer range. |
static Long |
Buffer.parseLong(Buffer b)
Very efficient method for parsing a
Long from the given Buffer. |
static Long |
Buffer.parseLong(Buffer b,
int start,
int end)
Very efficient method for parsing a
Long from the given Buffer range. |
Buffer |
Buffer.prepend(Buffer b)
Prepend the given
Buffer to this Buffer. |
Iterable<Buffer.View> |
Buffer.split(Buffer delimiter)
Split this buffer on the given delimiter and leave the delimiter on the end of each segment.
|
Iterable<Buffer.View> |
Buffer.split(Buffer delimiter,
boolean stripDelimiter)
Split this buffer on the given delimiter.
|
Iterable<Buffer.View> |
Buffer.split(List<Buffer.View> views,
Buffer delimiter,
boolean stripDelimiter)
Split this buffer on the given delimiter.
|
Modifier and Type | Method and Description |
---|---|
void |
BufferAllocator.release(List<Reference<Buffer>> batch) |
Constructor and Description |
---|
Buffer(Buffer bufferToCopy)
Copy constructor that creates a shallow copy of the given Buffer by calling
ByteBuffer.duplicate() on the underlying ByteBuffer . |
Modifier and Type | Field and Description |
---|---|
static Codec<Buffer,Buffer,Buffer> |
StandardCodecs.PASS_THROUGH_CODEC |
static Codec<Buffer,Buffer,Buffer> |
StandardCodecs.PASS_THROUGH_CODEC |
static Codec<Buffer,Buffer,Buffer> |
StandardCodecs.PASS_THROUGH_CODEC |
Modifier and Type | Method and Description |
---|---|
protected Buffer |
Codec.addDelimiterIfAny(Buffer buffer)
Add a trailing delimiter if defined
|
Buffer |
ByteArrayCodec.apply(byte[] bytes) |
Buffer |
FrameCodec.apply(Frame frame) |
Buffer |
SerializationCodec.apply(OUT out) |
Buffer |
DelimitedCodec.apply(OUT out) |
Buffer |
LengthFieldCodec.apply(OUT out) |
Buffer |
StringCodec.apply(String s) |
Buffer |
StringCodec.StringEncoder.apply(String s) |
Buffer |
JavaSerializationCodec.apply(T t) |
protected Buffer |
StringCodec.encode(String s,
CharsetEncoder charsetEncoder) |
Buffer |
Frame.getData() |
Buffer |
Frame.getPrefix() |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,byte[]> |
ByteArrayCodec.decoder(Consumer<byte[]> next) |
Function<Buffer,Frame> |
FrameCodec.decoder(Consumer<Frame> next) |
Function<Buffer,IN> |
SerializationCodec.decoder(Consumer<IN> next) |
Function<Buffer,IN> |
DelimitedCodec.decoder(Consumer<IN> next) |
Function<Buffer,IN> |
LengthFieldCodec.decoder(Consumer<IN> next) |
Function<Buffer,String> |
StringCodec.decoder(Consumer<String> next) |
Function<Buffer,T> |
JavaSerializationCodec.decoder(Consumer<T> next) |
org.reactivestreams.Publisher<Buffer> |
BufferCodec.encode(org.reactivestreams.Publisher<? extends OUT> publisherToEncode) |
Function<String,Buffer> |
StringCodec.encoder() |
Modifier and Type | Method and Description |
---|---|
protected Buffer |
Codec.addDelimiterIfAny(Buffer buffer)
Add a trailing delimiter if defined
|
protected String |
StringCodec.decode(Buffer buffer,
CharsetDecoder charsetDecoder) |
protected String |
StringCodec.doBufferDecode(Buffer buffer) |
protected IN |
Codec.doBufferDecode(Buffer buffer)
Decode a buffer
|
protected IN |
Codec.doDelimitedBufferDecode(Consumer<IN> decoderCallback,
Buffer buffer)
Helper method to scan for delimiting byte the codec might benefit from, e.g.
|
Class<IN> |
SerializationCodec.readType(Buffer buffer) |
Modifier and Type | Method and Description |
---|---|
org.reactivestreams.Publisher<IN> |
BufferCodec.decode(org.reactivestreams.Publisher<? extends Buffer> publisherToDecode) |
Constructor and Description |
---|
Frame(Buffer prefix,
Buffer data) |
Constructor and Description |
---|
DelimitedCodec(boolean stripDelimiter,
Codec<Buffer,IN,OUT> delegate)
Create a line-feed-delimited codec, using the given
Codec as a delegate. |
DelimitedCodec(byte delimiter,
boolean stripDelimiter,
Codec<Buffer,IN,OUT> delegate)
Create a delimited codec using the given delimiter and using the given
Codec
as a delegate. |
DelimitedCodec(Codec<Buffer,IN,OUT> delegate)
Create a line-feed-delimited codec, using the given
Codec as a delegate. |
LengthFieldCodec(Codec<Buffer,IN,OUT> delegate)
Create a length-field codec that reads the first integer as the length of the
remaining message.
|
LengthFieldCodec(int lengthFieldLength,
Codec<Buffer,IN,OUT> delegate)
Create a length-field codec that reads the first short, integer, or long as the
length of the remaining message, and prepends a short, integer, long to its output.
|
Modifier and Type | Method and Description |
---|---|
Buffer |
CompressionCodec.apply(OUT out) |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
CompressionCodec.decoder(Consumer<IN> next) |
Constructor and Description |
---|
CompressionCodec(Codec<Buffer,IN,OUT> delegate) |
GzipCodec(Codec<Buffer,IN,OUT> delegate) |
SnappyCodec(Codec<Buffer,IN,OUT> delegate) |
Modifier and Type | Method and Description |
---|---|
Buffer |
JsonCodec.apply(OUT out) |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
JsonCodec.decoder(Consumer<IN> next) |
Modifier and Type | Method and Description |
---|---|
protected IN |
JsonCodec.doBufferDecode(Buffer buffer) |
Modifier and Type | Field and Description |
---|---|
protected Codec<Buffer,IN,OUT> |
Spec.PeerSpec.codec |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
ChannelStream.getDecoder() |
Codec<Buffer,IN,OUT> |
ReactorPeer.getDefaultCodec()
Get the
Codec in use. |
Function<OUT,Buffer> |
ChannelStream.getEncoder() |
static HttpClient<Buffer,Buffer> |
NetStreams.httpClient() |
static HttpClient<Buffer,Buffer> |
NetStreams.httpClient() |
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer()
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer()
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(int port)
Build a simple Netty HTTP server listening on 127.0.0.1 and the passed port
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(int port)
Build a simple Netty HTTP server listening on 127.0.0.1 and the passed port
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(String bindAddress)
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(String bindAddress)
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(String bindAddress,
int port)
Build a simple Netty HTTP server listening othe passed bind address and port
|
static HttpServer<Buffer,Buffer> |
NetStreams.httpServer(String bindAddress,
int port)
Build a simple Netty HTTP server listening othe passed bind address and port
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient()
Bind a new TCP client to the localhost on port 12012.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient()
Bind a new TCP client to the localhost on port 12012.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(int port)
Bind a new TCP client to "loopback" on the the specified port.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(int port)
Bind a new TCP client to "loopback" on the the specified port.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(String bindAddress)
Bind a new TCP client to the specified connect address and port 12012.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(String bindAddress)
Bind a new TCP client to the specified connect address and port 12012.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(String bindAddress,
int port)
Bind a new TCP client to the specified connect address and port.
|
static TcpClient<Buffer,Buffer> |
NetStreams.tcpClient(String bindAddress,
int port)
Bind a new TCP client to the specified connect address and port.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer()
Bind a new TCP server to "loopback" on port 12012.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer()
Bind a new TCP server to "loopback" on port 12012.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(int port)
Bind a new TCP server to "loopback" on the given port.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(int port)
Bind a new TCP server to "loopback" on the given port.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(String bindAddress)
Bind a new TCP server to the given bind address on port 12012.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(String bindAddress)
Bind a new TCP server to the given bind address on port 12012.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(String bindAddress,
int port)
Bind a new TCP server to the given bind address and port.
|
static TcpServer<Buffer,Buffer> |
NetStreams.tcpServer(String bindAddress,
int port)
Bind a new TCP server to the given bind address and port.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer()
Bind a new UDP server to the "loopback" address.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer()
Bind a new UDP server to the "loopback" address.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(int port)
Bind a new UDP server to the "loopback" address and specified port.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(int port)
Bind a new UDP server to the "loopback" address and specified port.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(String bindAddress)
Bind a new UDP server to the given bind address.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(String bindAddress)
Bind a new UDP server to the given bind address.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(String bindAddress,
int port)
Bind a new UDP server to the given bind address and port.
|
static DatagramServer<Buffer,Buffer> |
NetStreams.udpServer(String bindAddress,
int port)
Bind a new UDP server to the given bind address and port.
|
Modifier and Type | Method and Description |
---|---|
S |
Spec.PeerSpec.codec(Codec<Buffer,IN,OUT> codec)
The
Codec to use to encode and decode data. |
Spec.TcpClientSpec<IN,OUT> |
Spec.TcpClientSpec.codec(Codec<Buffer,IN,OUT> codec)
The
Codec to use to encode and decode data. |
Spec.HttpClientSpec<IN,OUT> |
Spec.HttpClientSpec.codec(Codec<Buffer,IN,OUT> codec)
The
Codec to use to encode and decode data. |
Stream<Void> |
ChannelStream.writeBufferWith(org.reactivestreams.Publisher<? extends Buffer> source)
Write Buffer directly to be encoded if any codec has been setup
|
Constructor and Description |
---|
ChannelStream(Environment env,
Codec<Buffer,IN,OUT> codec,
long prefetch,
Dispatcher eventsDispatcher) |
ReactorClient(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec,
long prefetch) |
ReactorPeer(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec) |
ReactorPeer(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec,
long prefetch) |
Modifier and Type | Method and Description |
---|---|
Buffer |
SyslogCodec.apply(Void v) |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,SyslogMessage> |
SyslogCodec.decoder(Consumer<SyslogMessage> next) |
Constructor and Description |
---|
HttpClient(Environment env,
Dispatcher dispatcher,
Codec<Buffer,IN,OUT> codec,
ClientSocketOptions options) |
HttpServer(Environment env,
Dispatcher dispatcher,
Codec<Buffer,IN,OUT> codec) |
Modifier and Type | Method and Description |
---|---|
protected static io.netty.buffer.ByteBuf |
NettyChannelHandlerBridge.convertBufferToByteBuff(io.netty.channel.ChannelHandlerContext ctx,
Buffer data) |
Constructor and Description |
---|
NettyChannelStream(Environment env,
Codec<Buffer,IN,OUT> codec,
long prefetch,
Dispatcher eventsDispatcher,
io.netty.channel.Channel ioChannel) |
Constructor and Description |
---|
NettyHttpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec)
Creates a new NettyTcpClient that will use the given
env for configuration and the given reactor to
send events. |
NettyHttpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
NettyTcpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> hostSupplier,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec)
Creates a new NettyTcpClient that will use the given
env for configuration and the given reactor to
send events. |
NettyTcpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
NettyDatagramServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
NetworkInterface multicastInterface,
ServerSocketOptions options,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
ZeroMQChannelStream(Environment env,
long prefetch,
Dispatcher eventsDispatcher,
InetSocketAddress remoteAddress,
Codec<Buffer,IN,OUT> codec) |
Modifier and Type | Method and Description |
---|---|
ZeroMQ<T> |
ZeroMQ.codec(Codec<Buffer,T,T> codec) |
Constructor and Description |
---|
ZeroMQTcpClient(Environment env,
Dispatcher eventsDispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
ZeroMQTcpServer(Environment env,
Dispatcher eventsDispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
TcpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
TcpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
DatagramServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
NetworkInterface multicastInterface,
ServerSocketOptions options,
Codec<Buffer,IN,OUT> codec) |
Modifier and Type | Method and Description |
---|---|
Codec<Buffer,T,T> |
ChronicleQueuePersistor.codec() |
Constructor and Description |
---|
ChronicleQueuePersistor(String basePath,
Codec<Buffer,T,T> codec,
boolean clearOnStart,
boolean deleteOnExit,
net.openhft.chronicle.ChronicleQueueBuilder config)
Create an
ChronicleQueuePersistor based on the given base path, encoder and decoder. |
Modifier and Type | Method and Description |
---|---|
PersistentQueueSpec<T> |
PersistentQueueSpec.codec(Codec<Buffer,T,T> codec) |
Modifier and Type | Field and Description |
---|---|
protected Codec<Buffer,K,K> |
ChronicleReaderStream.keyCodec |
protected Codec<Buffer,V,V> |
ChronicleReaderStream.valueCodec |
Modifier and Type | Method and Description |
---|---|
Codec<Buffer,K,K> |
ChronicleReaderStream.keyCodec() |
Codec<Buffer,V,V> |
ChronicleReaderStream.valueCodec() |
Constructor and Description |
---|
ChronicleReaderStream(String name,
net.openhft.chronicle.Chronicle chronicle,
Codec<Buffer,K,K> keyCodec,
Codec<Buffer,V,V> valueCodec) |
ChronicleReaderStream(String name,
net.openhft.chronicle.Chronicle chronicle,
Codec<Buffer,K,K> keyCodec,
Codec<Buffer,V,V> valueCodec) |
ChronicleStream(String name,
int messageSizeHint,
net.openhft.chronicle.Chronicle chronicle,
Codec<Buffer,K,K> keyCodec,
Codec<Buffer,V,V> valueCodec) |
ChronicleStream(String name,
int messageSizeHint,
net.openhft.chronicle.Chronicle chronicle,
Codec<Buffer,K,K> keyCodec,
Codec<Buffer,V,V> valueCodec) |
Copyright © 2017. All rights reserved.