Uses of Class
io.vertx.mutiny.core.buffer.Buffer
-
-
Uses of Buffer in io.vertx.mutiny.amqp
Methods in io.vertx.mutiny.amqp that return Buffer Modifier and Type Method Description Buffer
AmqpMessage. bodyAsBinary()
Methods in io.vertx.mutiny.amqp with parameters of type Buffer Modifier and Type Method Description AmqpMessageBuilder
AmqpMessageBuilder. withBufferAsBody(Buffer buffer)
-
Uses of Buffer in io.vertx.mutiny.core.buffer
Fields in io.vertx.mutiny.core.buffer with type parameters of type Buffer Modifier and Type Field Description static TypeArg<Buffer>
Buffer. __TYPE_ARG
Methods in io.vertx.mutiny.core.buffer that return Buffer Modifier and Type Method Description Buffer
Buffer. appendBuffer(Buffer buff)
Buffer
Buffer. appendBuffer(Buffer buff, int offset, int len)
Buffer
Buffer. appendByte(byte b)
Buffer
Buffer. appendBytes(byte[] bytes)
Buffer
Buffer. appendBytes(byte[] bytes, int offset, int len)
Buffer
Buffer. appendDouble(double d)
Buffer
Buffer. appendFloat(float f)
Buffer
Buffer. appendInt(int i)
Buffer
Buffer. appendIntLE(int i)
Buffer
Buffer. appendLong(long l)
Buffer
Buffer. appendLongLE(long l)
Buffer
Buffer. appendMedium(int i)
Buffer
Buffer. appendMediumLE(int i)
Buffer
Buffer. appendShort(short s)
Buffer
Buffer. appendShortLE(short s)
Buffer
Buffer. appendString(String str)
Buffer
Buffer. appendString(String str, String enc)
Buffer
Buffer. appendUnsignedByte(short b)
Buffer
Buffer. appendUnsignedInt(long i)
Buffer
Buffer. appendUnsignedIntLE(long i)
Buffer
Buffer. appendUnsignedShort(int s)
Buffer
Buffer. appendUnsignedShortLE(int s)
static Buffer
Buffer. buffer()
static Buffer
Buffer. buffer(byte[] bytes)
static Buffer
Buffer. buffer(int initialSizeHint)
static Buffer
Buffer. buffer(io.netty.buffer.ByteBuf byteBuf)
Deprecated.removed from public API in Vert.x 5static Buffer
Buffer. buffer(String string)
static Buffer
Buffer. buffer(String string, String enc)
Buffer
Buffer. copy()
Buffer
Buffer. getBuffer(int start, int end)
Buffer
Buffer. getBytes(byte[] dst)
Buffer
Buffer. getBytes(byte[] dst, int dstIndex)
Buffer
Buffer. getBytes(int start, int end, byte[] dst)
Buffer
Buffer. getBytes(int start, int end, byte[] dst, int dstIndex)
static Buffer
Buffer. newInstance(io.vertx.core.buffer.Buffer arg)
Buffer
Buffer. setBuffer(int pos, Buffer b)
Buffer
Buffer. setBuffer(int pos, Buffer b, int offset, int len)
Buffer
Buffer. setByte(int pos, byte b)
Buffer
Buffer. setBytes(int pos, byte[] b)
Buffer
Buffer. setBytes(int pos, byte[] b, int offset, int len)
Buffer
Buffer. setBytes(int pos, ByteBuffer b)
Buffer
Buffer. setDouble(int pos, double d)
Buffer
Buffer. setFloat(int pos, float f)
Buffer
Buffer. setInt(int pos, int i)
Buffer
Buffer. setIntLE(int pos, int i)
Buffer
Buffer. setLong(int pos, long l)
Buffer
Buffer. setLongLE(int pos, long l)
Buffer
Buffer. setMedium(int pos, int i)
Buffer
Buffer. setMediumLE(int pos, int i)
Buffer
Buffer. setShort(int pos, short s)
Buffer
Buffer. setShortLE(int pos, short s)
Buffer
Buffer. setString(int pos, String str)
Buffer
Buffer. setString(int pos, String str, String enc)
Buffer
Buffer. setUnsignedByte(int pos, short b)
Buffer
Buffer. setUnsignedInt(int pos, long i)
Buffer
Buffer. setUnsignedIntLE(int pos, long i)
Buffer
Buffer. setUnsignedShort(int pos, int s)
Buffer
Buffer. setUnsignedShortLE(int pos, int s)
Buffer
Buffer. slice()
Buffer
Buffer. slice(int start, int end)
Methods in io.vertx.mutiny.core.buffer with parameters of type Buffer Modifier and Type Method Description Buffer
Buffer. appendBuffer(Buffer buff)
Buffer
Buffer. appendBuffer(Buffer buff, int offset, int len)
Buffer
Buffer. setBuffer(int pos, Buffer b)
Buffer
Buffer. setBuffer(int pos, Buffer b, int offset, int len)
-
Uses of Buffer in io.vertx.mutiny.core.datagram
Methods in io.vertx.mutiny.core.datagram that return Buffer Modifier and Type Method Description Buffer
DatagramPacket. data()
Methods in io.vertx.mutiny.core.datagram that return types with arguments of type Buffer Modifier and Type Method Description WriteStream<Buffer>
DatagramSocket. sender(int port, String host)
Methods in io.vertx.mutiny.core.datagram with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
DatagramSocket. send(Buffer packet, int port, String host)
Write the givenBuffer
to theSocketAddress
.Void
DatagramSocket. sendAndAwait(Buffer packet, int port, String host)
Blocking variant ofDatagramSocket.send(io.vertx.mutiny.core.buffer.Buffer,int,String)
.DatagramSocket
DatagramSocket. sendAndForget(Buffer packet, int port, String host)
Variant ofDatagramSocket.send(io.vertx.mutiny.core.buffer.Buffer,int,String)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.core.file
Methods in io.vertx.mutiny.core.file that return Buffer Modifier and Type Method Description Buffer
AsyncFile. readAndAwait(Buffer buffer, int offset, long position, int length)
Blocking variant ofAsyncFile.read(io.vertx.mutiny.core.buffer.Buffer,int,long,int)
.Buffer
FileSystem. readFileAndAwait(String path)
Blocking variant ofFileSystem.readFile(String)
.Buffer
FileSystem. readFileBlocking(String path)
Methods in io.vertx.mutiny.core.file that return types with arguments of type Buffer Modifier and Type Method Description Pipe<Buffer>
AsyncFile. pipe()
io.smallrye.mutiny.Uni<Buffer>
AsyncFile. read(Buffer buffer, int offset, long position, int length)
Readslength
bytes of data from the file at positionposition
in the file, asynchronously.io.smallrye.mutiny.Uni<Buffer>
FileSystem. readFile(String path)
Reads the entire file as represented by the pathpath
as a , asynchronously.Iterable<Buffer>
AsyncFile. toBlockingIterable()
Stream<Buffer>
AsyncFile. toBlockingStream()
io.smallrye.mutiny.Multi<Buffer>
AsyncFile. toMulti()
WriteStreamSubscriber<Buffer>
AsyncFile. toSubscriber()
Methods in io.vertx.mutiny.core.file with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
AsyncFile. end(Buffer data)
Same as but with anhandler
called when the operation completesVoid
AsyncFile. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.void
AsyncFile. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Buffer>
AsyncFile. read(Buffer buffer, int offset, long position, int length)
Readslength
bytes of data from the file at positionposition
in the file, asynchronously.Buffer
AsyncFile. readAndAwait(Buffer buffer, int offset, long position, int length)
Blocking variant ofAsyncFile.read(io.vertx.mutiny.core.buffer.Buffer,int,long,int)
.AsyncFile
AsyncFile. readAndForget(Buffer buffer, int offset, long position, int length)
Variant ofAsyncFile.read(io.vertx.mutiny.core.buffer.Buffer,int,long,int)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
AsyncFile. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
AsyncFile. write(Buffer buffer, long position)
Write aBuffer
to the file at positionposition
in the file, asynchronously.Void
AsyncFile. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
AsyncFile. writeAndAwait(Buffer buffer, long position)
Blocking variant ofAsyncFile.write(io.vertx.mutiny.core.buffer.Buffer,long)
.void
AsyncFile. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
AsyncFile. writeAndForget(Buffer buffer, long position)
Variant ofAsyncFile.write(io.vertx.mutiny.core.buffer.Buffer,long)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
FileSystem. writeFile(String path, Buffer data)
Creates the file, and writes the specifiedBuffer data
to the file represented by the pathpath
, asynchronously.Void
FileSystem. writeFileAndAwait(String path, Buffer data)
Blocking variant ofFileSystem.writeFile(String,io.vertx.mutiny.core.buffer.Buffer)
.FileSystem
FileSystem. writeFileAndForget(String path, Buffer data)
Variant ofFileSystem.writeFile(String,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.FileSystem
FileSystem. writeFileBlocking(String path, Buffer data)
Method parameters in io.vertx.mutiny.core.file with type arguments of type Buffer Modifier and Type Method Description AsyncFile
AsyncFile. handler(Consumer<Buffer> handler)
io.smallrye.mutiny.Uni<Void>
AsyncFile. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.Void
AsyncFile. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.void
AsyncFile. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.core.http
Fields in io.vertx.mutiny.core.http with type parameters of type Buffer Modifier and Type Field Description static TypeArg<Buffer>
WebSocketBase. TYPE_ARG_0
Methods in io.vertx.mutiny.core.http that return Buffer Modifier and Type Method Description Buffer
WebSocketFrame. binaryData()
Buffer
HttpClientResponse. bodyAndAwait()
Blocking variant ofHttpClientResponse.body()
.Buffer
HttpServerRequest. bodyAndAwait()
Blocking variant ofHttpServerRequest.body()
.Buffer
HttpFrame. payload()
Buffer
HttpConnection. pingAndAwait(Buffer data)
Blocking variant ofHttpConnection.ping(io.vertx.mutiny.core.buffer.Buffer)
.Methods in io.vertx.mutiny.core.http that return types with arguments of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Buffer>
HttpClientResponse. body()
Same asHttpClientResponse.body()
but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Buffer>
HttpServerRequest. body()
Same asHttpServerRequest.body()
but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Buffer>
HttpConnection. ping(Buffer data)
Send a frame to the remote endpoint.Pipe<Buffer>
ClientWebSocket. pipe()
Pipe<Buffer>
HttpClientResponse. pipe()
Pipe<Buffer>
HttpServerFileUpload. pipe()
Pipe<Buffer>
HttpServerRequest. pipe()
Pipe<Buffer>
ServerWebSocket. pipe()
Pipe<Buffer>
WebSocket. pipe()
Pipe<Buffer>
WebSocketBase. pipe()
Iterable<Buffer>
ClientWebSocket. toBlockingIterable()
Iterable<Buffer>
HttpClientResponse. toBlockingIterable()
Iterable<Buffer>
HttpServerFileUpload. toBlockingIterable()
Iterable<Buffer>
HttpServerRequest. toBlockingIterable()
Iterable<Buffer>
ServerWebSocket. toBlockingIterable()
Iterable<Buffer>
WebSocket. toBlockingIterable()
Stream<Buffer>
ClientWebSocket. toBlockingStream()
Stream<Buffer>
HttpClientResponse. toBlockingStream()
Stream<Buffer>
HttpServerFileUpload. toBlockingStream()
Stream<Buffer>
HttpServerRequest. toBlockingStream()
Stream<Buffer>
ServerWebSocket. toBlockingStream()
Stream<Buffer>
WebSocket. toBlockingStream()
io.smallrye.mutiny.Multi<Buffer>
ClientWebSocket. toMulti()
io.smallrye.mutiny.Multi<Buffer>
HttpClientResponse. toMulti()
io.smallrye.mutiny.Multi<Buffer>
HttpServerFileUpload. toMulti()
io.smallrye.mutiny.Multi<Buffer>
HttpServerRequest. toMulti()
io.smallrye.mutiny.Multi<Buffer>
ServerWebSocket. toMulti()
io.smallrye.mutiny.Multi<Buffer>
WebSocket. toMulti()
WriteStreamSubscriber<Buffer>
ClientWebSocket. toSubscriber()
WriteStreamSubscriber<Buffer>
HttpClientRequest. toSubscriber()
WriteStreamSubscriber<Buffer>
HttpServerResponse. toSubscriber()
WriteStreamSubscriber<Buffer>
ServerWebSocket. toSubscriber()
WriteStreamSubscriber<Buffer>
WebSocket. toSubscriber()
Methods in io.vertx.mutiny.core.http with parameters of type Buffer Modifier and Type Method Description static WebSocketFrame
WebSocketFrame. binaryFrame(Buffer data, boolean isFinal)
static WebSocketFrame
WebSocketFrame. continuationFrame(Buffer data, boolean isFinal)
io.smallrye.mutiny.Uni<Void>
ClientWebSocket. end(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
HttpClientRequest. end(Buffer chunk)
Same asHttpClientRequest.end(java.lang.String)
but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
HttpServerResponse. end(Buffer chunk)
Same asHttpServerResponse.end()
but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
ServerWebSocket. end(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
WebSocket. end(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
WebSocketBase. end(Buffer data)
Same as but with anhandler
called when the operation completesVoid
ClientWebSocket. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.Void
HttpClientRequest. endAndAwait(Buffer chunk)
Blocking variant ofHttpClientRequest.end(io.vertx.mutiny.core.buffer.Buffer)
.Void
HttpServerResponse. endAndAwait(Buffer chunk)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.Void
ServerWebSocket. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.Void
WebSocket. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.Void
WebSocketBase. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.void
ClientWebSocket. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
HttpClientRequest. endAndForget(Buffer chunk)
Variant ofHttpClientRequest.end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
HttpServerResponse. endAndForget(Buffer chunk)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
ServerWebSocket. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
WebSocket. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
WebSocketBase. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.HttpConnection
HttpConnection. goAway(long errorCode, int lastStreamId, Buffer debugData)
io.smallrye.mutiny.Uni<Buffer>
HttpConnection. ping(Buffer data)
Send a frame to the remote endpoint.Buffer
HttpConnection. pingAndAwait(Buffer data)
Blocking variant ofHttpConnection.ping(io.vertx.mutiny.core.buffer.Buffer)
.HttpConnection
HttpConnection. pingAndForget(Buffer data)
Variant ofHttpConnection.ping(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.static WebSocketFrame
WebSocketFrame. pingFrame(Buffer data)
static WebSocketFrame
WebSocketFrame. pongFrame(Buffer data)
io.smallrye.mutiny.Uni<HttpClientResponse>
HttpClientRequest. send(Buffer body)
Send the request with a bufferbody
.io.smallrye.mutiny.Uni<Void>
HttpServerResponse. send(Buffer body)
Send the request with a bufferbody
.HttpClientResponse
HttpClientRequest. sendAndAwait(Buffer body)
Blocking variant ofHttpClientRequest.send(io.vertx.mutiny.core.buffer.Buffer)
.Void
HttpServerResponse. sendAndAwait(Buffer body)
Blocking variant ofHttpServerResponse.send(io.vertx.mutiny.core.buffer.Buffer)
.void
HttpClientRequest. sendAndForget(Buffer body)
Variant ofHttpClientRequest.send(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
HttpServerResponse. sendAndForget(Buffer body)
Variant ofHttpServerResponse.send(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
ClientWebSocket. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
HttpClientRequest. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
HttpServerResponse. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
ServerWebSocket. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
WebSocket. write(Buffer data)
Same as but with anhandler
called when the operation completesio.smallrye.mutiny.Uni<Void>
WebSocketBase. write(Buffer data)
Same as but with anhandler
called when the operation completesVoid
ClientWebSocket. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
HttpClientRequest. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
HttpServerResponse. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
ServerWebSocket. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
WebSocket. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.Void
WebSocketBase. writeAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.void
ClientWebSocket. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
HttpClientRequest. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
HttpServerResponse. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
ServerWebSocket. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
WebSocket. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
WebSocketBase. writeAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
ClientWebSocket. writeBinaryMessage(Buffer data)
io.smallrye.mutiny.Uni<Void>
ServerWebSocket. writeBinaryMessage(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocket. writeBinaryMessage(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocketBase. writeBinaryMessage(Buffer data)
Same asWebSocketBase.writeBinaryMessage(io.vertx.mutiny.core.buffer.Buffer)
but with anhandler
called when the operation completesVoid
ClientWebSocket. writeBinaryMessageAndAwait(Buffer data)
Void
ServerWebSocket. writeBinaryMessageAndAwait(Buffer data)
Void
WebSocket. writeBinaryMessageAndAwait(Buffer data)
Void
WebSocketBase. writeBinaryMessageAndAwait(Buffer data)
Blocking variant ofWebSocketBase.writeBinaryMessage(io.vertx.mutiny.core.buffer.Buffer)
.ClientWebSocket
ClientWebSocket. writeBinaryMessageAndForget(Buffer data)
ServerWebSocket
ServerWebSocket. writeBinaryMessageAndForget(Buffer data)
WebSocket
WebSocket. writeBinaryMessageAndForget(Buffer data)
WebSocketBase
WebSocketBase. writeBinaryMessageAndForget(Buffer data)
Variant ofWebSocketBase.writeBinaryMessage(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.HttpClientRequest
HttpClientRequest. writeCustomFrame(int type, int flags, Buffer payload)
HttpServerResponse
HttpServerResponse. writeCustomFrame(int type, int flags, Buffer payload)
io.smallrye.mutiny.Uni<Void>
ClientWebSocket. writeFinalBinaryFrame(Buffer data)
io.smallrye.mutiny.Uni<Void>
ServerWebSocket. writeFinalBinaryFrame(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocket. writeFinalBinaryFrame(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocketBase. writeFinalBinaryFrame(Buffer data)
Same asWebSocketBase.writeFinalBinaryFrame(io.vertx.mutiny.core.buffer.Buffer)
but with anhandler
called when the operation completesVoid
ClientWebSocket. writeFinalBinaryFrameAndAwait(Buffer data)
Void
ServerWebSocket. writeFinalBinaryFrameAndAwait(Buffer data)
Void
WebSocket. writeFinalBinaryFrameAndAwait(Buffer data)
Void
WebSocketBase. writeFinalBinaryFrameAndAwait(Buffer data)
Blocking variant ofWebSocketBase.writeFinalBinaryFrame(io.vertx.mutiny.core.buffer.Buffer)
.ClientWebSocket
ClientWebSocket. writeFinalBinaryFrameAndForget(Buffer data)
ServerWebSocket
ServerWebSocket. writeFinalBinaryFrameAndForget(Buffer data)
WebSocket
WebSocket. writeFinalBinaryFrameAndForget(Buffer data)
WebSocketBase
WebSocketBase. writeFinalBinaryFrameAndForget(Buffer data)
Variant ofWebSocketBase.writeFinalBinaryFrame(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
ClientWebSocket. writePing(Buffer data)
io.smallrye.mutiny.Uni<Void>
ServerWebSocket. writePing(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocket. writePing(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocketBase. writePing(Buffer data)
Writes a ping frame to the connection.Void
ClientWebSocket. writePingAndAwait(Buffer data)
Void
ServerWebSocket. writePingAndAwait(Buffer data)
Void
WebSocket. writePingAndAwait(Buffer data)
Void
WebSocketBase. writePingAndAwait(Buffer data)
Blocking variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer)
.ClientWebSocket
ClientWebSocket. writePingAndForget(Buffer data)
ServerWebSocket
ServerWebSocket. writePingAndForget(Buffer data)
WebSocket
WebSocket. writePingAndForget(Buffer data)
WebSocketBase
WebSocketBase. writePingAndForget(Buffer data)
Variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
ClientWebSocket. writePong(Buffer data)
io.smallrye.mutiny.Uni<Void>
ServerWebSocket. writePong(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocket. writePong(Buffer data)
io.smallrye.mutiny.Uni<Void>
WebSocketBase. writePong(Buffer data)
Writes a pong frame to the connection.Void
ClientWebSocket. writePongAndAwait(Buffer data)
Void
ServerWebSocket. writePongAndAwait(Buffer data)
Void
WebSocket. writePongAndAwait(Buffer data)
Void
WebSocketBase. writePongAndAwait(Buffer data)
Blocking variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer)
.ClientWebSocket
ClientWebSocket. writePongAndForget(Buffer data)
ServerWebSocket
ServerWebSocket. writePongAndForget(Buffer data)
WebSocket
WebSocket. writePongAndForget(Buffer data)
WebSocketBase
WebSocketBase. writePongAndForget(Buffer data)
Variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.Method parameters in io.vertx.mutiny.core.http with type arguments of type Buffer Modifier and Type Method Description ClientWebSocket
ClientWebSocket. binaryMessageHandler(Consumer<Buffer> handler)
WebSocketBase
ServerWebSocket. binaryMessageHandler(Consumer<Buffer> handler)
WebSocketBase
WebSocket. binaryMessageHandler(Consumer<Buffer> handler)
WebSocketBase
WebSocketBase. binaryMessageHandler(Consumer<Buffer> handler)
HttpClientResponse
HttpClientResponse. bodyHandler(Consumer<Buffer> bodyHandler)
HttpServerRequest
HttpServerRequest. bodyHandler(Consumer<Buffer> bodyHandler)
ClientWebSocket
ClientWebSocket. handler(Consumer<Buffer> handler)
HttpClientResponse
HttpClientResponse. handler(Consumer<Buffer> handler)
HttpServerFileUpload
HttpServerFileUpload. handler(Consumer<Buffer> handler)
HttpServerRequest
HttpServerRequest. handler(Consumer<Buffer> handler)
ServerWebSocket
ServerWebSocket. handler(Consumer<Buffer> handler)
WebSocket
WebSocket. handler(Consumer<Buffer> handler)
WebSocketBase
WebSocketBase. handler(Consumer<Buffer> handler)
HttpConnection
HttpConnection. pingHandler(Consumer<Buffer> handler)
io.smallrye.mutiny.Uni<Void>
ClientWebSocket. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
HttpClientResponse. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
HttpServerFileUpload. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
HttpServerRequest. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
ServerWebSocket. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
WebSocket. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.io.smallrye.mutiny.Uni<Void>
WebSocketBase. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.Void
ClientWebSocket. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
HttpClientResponse. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
HttpServerFileUpload. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
HttpServerRequest. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
ServerWebSocket. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
WebSocket. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.Void
WebSocketBase. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.void
ClientWebSocket. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
HttpClientResponse. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
HttpServerFileUpload. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
HttpServerRequest. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
ServerWebSocket. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
WebSocket. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
WebSocketBase. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.ClientWebSocket
ClientWebSocket. pongHandler(Consumer<Buffer> handler)
WebSocketBase
ServerWebSocket. pongHandler(Consumer<Buffer> handler)
WebSocketBase
WebSocket. pongHandler(Consumer<Buffer> handler)
WebSocketBase
WebSocketBase. pongHandler(Consumer<Buffer> handler)
io.smallrye.mutiny.Uni<HttpClientResponse>
HttpClientRequest. send(ReadStream<Buffer> body)
Send the request with a streambody
.io.smallrye.mutiny.Uni<HttpClientResponse>
HttpClientRequest. send(Flow.Publisher<Buffer> body)
Send the request with a streambody
.io.smallrye.mutiny.Uni<Void>
HttpServerResponse. send(ReadStream<Buffer> body)
Send the request with a streambody
.io.smallrye.mutiny.Uni<Void>
HttpServerResponse. send(Flow.Publisher<Buffer> body)
Send the request with a streambody
.HttpClientResponse
HttpClientRequest. sendAndAwait(ReadStream<Buffer> body)
Blocking variant ofHttpClientRequest.send(io.vertx.mutiny.core.streams.ReadStream)
.HttpClientResponse
HttpClientRequest. sendAndAwait(Flow.Publisher<Buffer> body)
Blocking variant ofio.vertx.mutiny.core.http.HttpClientRequest#send(Flow$Publisher)
.Void
HttpServerResponse. sendAndAwait(ReadStream<Buffer> body)
Blocking variant ofHttpServerResponse.send(io.vertx.mutiny.core.streams.ReadStream)
.Void
HttpServerResponse. sendAndAwait(Flow.Publisher<Buffer> body)
Blocking variant ofio.vertx.mutiny.core.http.HttpServerResponse#send(Flow$Publisher)
.void
HttpClientRequest. sendAndForget(ReadStream<Buffer> body)
Variant ofHttpClientRequest.send(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation.void
HttpClientRequest. sendAndForget(Flow.Publisher<Buffer> body)
Variant ofio.vertx.mutiny.core.http.HttpClientRequest#send(Flow$Publisher)
that ignores the result of the operation.void
HttpServerResponse. sendAndForget(ReadStream<Buffer> body)
Variant ofHttpServerResponse.send(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation.void
HttpServerResponse. sendAndForget(Flow.Publisher<Buffer> body)
Variant ofio.vertx.mutiny.core.http.HttpServerResponse#send(Flow$Publisher)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.core.net
Methods in io.vertx.mutiny.core.net that return types with arguments of type Buffer Modifier and Type Method Description Pipe<Buffer>
NetSocket. pipe()
Iterable<Buffer>
NetSocket. toBlockingIterable()
Stream<Buffer>
NetSocket. toBlockingStream()
io.smallrye.mutiny.Multi<Buffer>
NetSocket. toMulti()
WriteStreamSubscriber<Buffer>
NetSocket. toSubscriber()
Methods in io.vertx.mutiny.core.net with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
NetSocket. end(Buffer data)
Same as but with anhandler
called when the operation completesVoid
NetSocket. endAndAwait(Buffer data)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
.void
NetSocket. endAndForget(Buffer data)
Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
NetSocket. write(Buffer message)
LikeWriteStream.write(T)
but with anhandler
called when the message has been written or failed to be written.Void
NetSocket. writeAndAwait(Buffer message)
Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
.void
NetSocket. writeAndForget(Buffer message)
Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.Method parameters in io.vertx.mutiny.core.net with type arguments of type Buffer Modifier and Type Method Description NetSocket
NetSocket. handler(Consumer<Buffer> handler)
io.smallrye.mutiny.Uni<Void>
NetSocket. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.Void
NetSocket. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.void
NetSocket. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.core.parsetools
Methods in io.vertx.mutiny.core.parsetools that return Buffer Modifier and Type Method Description Buffer
JsonEvent. binaryValue()
Methods in io.vertx.mutiny.core.parsetools that return types with arguments of type Buffer Modifier and Type Method Description Pipe<Buffer>
RecordParser. pipe()
Iterable<Buffer>
RecordParser. toBlockingIterable()
Stream<Buffer>
RecordParser. toBlockingStream()
io.smallrye.mutiny.Multi<Buffer>
RecordParser. toMulti()
Methods in io.vertx.mutiny.core.parsetools with parameters of type Buffer Modifier and Type Method Description void
JsonParser. accept(Buffer item)
void
RecordParser. accept(Buffer item)
void
RecordParser. delimitedMode(Buffer delim)
void
JsonParser. handle(Buffer event)
void
RecordParser. handle(Buffer buffer)
static RecordParser
RecordParser. newDelimited(Buffer delim)
static RecordParser
RecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)
static RecordParser
RecordParser. newDelimited(Buffer delim, Flow.Publisher<Buffer> stream)
static RecordParser
RecordParser. newDelimited(Buffer delim, Consumer<Buffer> output)
JsonParser
JsonParser. write(Buffer buffer)
Method parameters in io.vertx.mutiny.core.parsetools with type arguments of type Buffer Modifier and Type Method Description RecordParser
RecordParser. handler(Consumer<Buffer> handler)
static RecordParser
RecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)
static RecordParser
RecordParser. newDelimited(Buffer delim, Flow.Publisher<Buffer> stream)
static RecordParser
RecordParser. newDelimited(Buffer delim, Consumer<Buffer> output)
static RecordParser
RecordParser. newDelimited(String delim, ReadStream<Buffer> stream)
static RecordParser
RecordParser. newDelimited(String delim, Flow.Publisher<Buffer> stream)
static RecordParser
RecordParser. newDelimited(String delim, Consumer<Buffer> output)
static RecordParser
RecordParser. newFixed(int size, ReadStream<Buffer> stream)
static RecordParser
RecordParser. newFixed(int size, Flow.Publisher<Buffer> stream)
static RecordParser
RecordParser. newFixed(int size, Consumer<Buffer> output)
static JsonParser
JsonParser. newParser(ReadStream<Buffer> stream)
static JsonParser
JsonParser. newParser(Flow.Publisher<Buffer> stream)
io.smallrye.mutiny.Uni<Void>
RecordParser. pipeTo(WriteStream<Buffer> dst)
Pipe thisReadStream
to theWriteStream
.Void
RecordParser. pipeToAndAwait(WriteStream<Buffer> dst)
Blocking variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
.void
RecordParser. pipeToAndForget(WriteStream<Buffer> dst)
Variant ofReadStream.pipeTo(io.vertx.mutiny.core.streams.WriteStream)
that ignores the result of the operation.void
RecordParser. setOutput(Consumer<Buffer> output)
-
Uses of Buffer in io.vertx.mutiny.ext.mail
Methods in io.vertx.mutiny.ext.mail that return Buffer Modifier and Type Method Description Buffer
MailAttachment. getData()
Methods in io.vertx.mutiny.ext.mail that return types with arguments of type Buffer Modifier and Type Method Description ReadStream<Buffer>
MailAttachment. getStream()
Methods in io.vertx.mutiny.ext.mail with parameters of type Buffer Modifier and Type Method Description MailAttachment
MailAttachment. setData(Buffer data)
Method parameters in io.vertx.mutiny.ext.mail with type arguments of type Buffer Modifier and Type Method Description MailAttachment
MailAttachment. setStream(ReadStream<Buffer> stream)
MailAttachment
MailAttachment. setStream(Flow.Publisher<Buffer> stream)
-
Uses of Buffer in io.vertx.mutiny.ext.mongo
Methods in io.vertx.mutiny.ext.mongo that return types with arguments of type Buffer Modifier and Type Method Description ReadStream<Buffer>
MongoGridFsClient. readByFileName(String fileName)
ReadStream<Buffer>
MongoGridFsClient. readByFileNameWithOptions(String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)
ReadStream<Buffer>
MongoGridFsClient. readById(String id)
Method parameters in io.vertx.mutiny.ext.mongo with type arguments of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Long>
MongoGridFsClient. downloadByFileName(WriteStream<Buffer> stream, String fileName)
Long
MongoGridFsClient. downloadByFileNameAndAwait(WriteStream<Buffer> stream, String fileName)
MongoGridFsClient
MongoGridFsClient. downloadByFileNameAndForget(WriteStream<Buffer> stream, String fileName)
io.smallrye.mutiny.Uni<Long>
MongoGridFsClient. downloadByFileNameWithOptions(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)
Long
MongoGridFsClient. downloadByFileNameWithOptionsAndAwait(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)
MongoGridFsClient
MongoGridFsClient. downloadByFileNameWithOptionsAndForget(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)
io.smallrye.mutiny.Uni<Long>
MongoGridFsClient. downloadById(WriteStream<Buffer> stream, String id)
Long
MongoGridFsClient. downloadByIdAndAwait(WriteStream<Buffer> stream, String id)
MongoGridFsClient
MongoGridFsClient. downloadByIdAndForget(WriteStream<Buffer> stream, String id)
io.smallrye.mutiny.Uni<String>
MongoGridFsClient. uploadByFileName(ReadStream<Buffer> stream, String fileName)
io.smallrye.mutiny.Uni<String>
MongoGridFsClient. uploadByFileName(Flow.Publisher<Buffer> stream, String fileName)
String
MongoGridFsClient. uploadByFileNameAndAwait(ReadStream<Buffer> stream, String fileName)
String
MongoGridFsClient. uploadByFileNameAndAwait(Flow.Publisher<Buffer> stream, String fileName)
MongoGridFsClient
MongoGridFsClient. uploadByFileNameAndForget(ReadStream<Buffer> stream, String fileName)
MongoGridFsClient
MongoGridFsClient. uploadByFileNameAndForget(Flow.Publisher<Buffer> stream, String fileName)
io.smallrye.mutiny.Uni<String>
MongoGridFsClient. uploadByFileNameWithOptions(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
io.smallrye.mutiny.Uni<String>
MongoGridFsClient. uploadByFileNameWithOptions(Flow.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
String
MongoGridFsClient. uploadByFileNameWithOptionsAndAwait(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
String
MongoGridFsClient. uploadByFileNameWithOptionsAndAwait(Flow.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
MongoGridFsClient
MongoGridFsClient. uploadByFileNameWithOptionsAndForget(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
MongoGridFsClient
MongoGridFsClient. uploadByFileNameWithOptionsAndForget(Flow.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
-
Uses of Buffer in io.vertx.mutiny.ext.stomp
Methods in io.vertx.mutiny.ext.stomp with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<io.vertx.ext.stomp.Frame>
StompClientConnection. send(String destination, Buffer body)
Sends aSEND
frame to the server to the given destination.io.smallrye.mutiny.Uni<io.vertx.ext.stomp.Frame>
StompClientConnection. send(String destination, Map<String,String> headers, Buffer body)
Sends aSEND
frame to the server to the given destination.io.smallrye.mutiny.Uni<io.vertx.ext.stomp.Frame>
StompClientConnection. send(Map<String,String> headers, Buffer body)
Sends aSEND
frame to the server.io.vertx.ext.stomp.Frame
StompClientConnection. sendAndAwait(String destination, Buffer body)
Blocking variant ofStompClientConnection.send(String,io.vertx.mutiny.core.buffer.Buffer)
.io.vertx.ext.stomp.Frame
StompClientConnection. sendAndAwait(String destination, Map<String,String> headers, Buffer body)
Blocking variant ofStompClientConnection.send(String,Map,io.vertx.mutiny.core.buffer.Buffer)
.io.vertx.ext.stomp.Frame
StompClientConnection. sendAndAwait(Map<String,String> headers, Buffer body)
Blocking variant ofStompClientConnection.send(Map,io.vertx.mutiny.core.buffer.Buffer)
.StompClientConnection
StompClientConnection. sendAndForget(String destination, Buffer body)
Variant ofStompClientConnection.send(String,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.StompClientConnection
StompClientConnection. sendAndForget(String destination, Map<String,String> headers, Buffer body)
Variant ofStompClientConnection.send(String,Map,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.StompClientConnection
StompClientConnection. sendAndForget(Map<String,String> headers, Buffer body)
Variant ofStompClientConnection.send(Map,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.StompServerConnection
StompServerConnection. write(Buffer buffer)
-
Uses of Buffer in io.vertx.mutiny.ext.web
Methods in io.vertx.mutiny.ext.web that return Buffer Modifier and Type Method Description Buffer
RequestBody. buffer()
Buffer
RoutingContext. getBody()
Deprecated.UseRoutingContext.body()
instead.Methods in io.vertx.mutiny.ext.web with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
RoutingContext. end(Buffer buffer)
Void
RoutingContext. endAndAwait(Buffer buffer)
Blocking variant ofRoutingContext.end(io.vertx.mutiny.core.buffer.Buffer)
.RoutingContext
RoutingContext. endAndForget(Buffer buffer)
Variant ofRoutingContext.end(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
RoutingContext. setBody(Buffer body)
Deprecated.This method is internal. -
Uses of Buffer in io.vertx.mutiny.ext.web.client
Methods in io.vertx.mutiny.ext.web.client that return Buffer Modifier and Type Method Description Buffer
HttpResponse. bodyAsBuffer()
Methods in io.vertx.mutiny.ext.web.client that return types with arguments of type Buffer Modifier and Type Method Description HttpRequest<Buffer>
WebClient. delete(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. delete(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. delete(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. delete(String requestURI)
HttpRequest<Buffer>
WebClient. delete(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. delete(String host, String requestURI)
HttpRequest<Buffer>
WebClient. deleteAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. deleteAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. get(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. get(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. get(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. get(String requestURI)
HttpRequest<Buffer>
WebClient. get(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. get(String host, String requestURI)
HttpRequest<Buffer>
WebClient. getAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. getAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. head(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. head(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. head(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. head(String requestURI)
HttpRequest<Buffer>
WebClient. head(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. head(String host, String requestURI)
HttpRequest<Buffer>
WebClient. headAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. headAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. patch(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. patch(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. patch(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. patch(String requestURI)
HttpRequest<Buffer>
WebClient. patch(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. patch(String host, String requestURI)
HttpRequest<Buffer>
WebClient. patchAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. patchAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. post(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. post(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. post(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. post(String requestURI)
HttpRequest<Buffer>
WebClient. post(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. post(String host, String requestURI)
HttpRequest<Buffer>
WebClient. postAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. postAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. put(int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. put(int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. put(UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. put(String requestURI)
HttpRequest<Buffer>
WebClient. put(String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. put(String host, String requestURI)
HttpRequest<Buffer>
WebClient. putAbs(UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. putAbs(String absoluteURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, io.vertx.core.http.RequestOptions options)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, int port, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, int port, String host, String requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, io.vertx.core.http.RequestOptions options)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, String requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, String host, String requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, String requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, String host, UriTemplate requestURI)
HttpRequest<Buffer>
WebClient. request(io.vertx.core.http.HttpMethod method, String host, String requestURI)
HttpRequest<Buffer>
WebClient. requestAbs(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. requestAbs(io.vertx.core.http.HttpMethod method, SocketAddress serverAddress, String absoluteURI)
HttpRequest<Buffer>
WebClient. requestAbs(io.vertx.core.http.HttpMethod method, UriTemplate absoluteURI)
HttpRequest<Buffer>
WebClient. requestAbs(io.vertx.core.http.HttpMethod method, String absoluteURI)
Methods in io.vertx.mutiny.ext.web.client with parameters of type Buffer Modifier and Type Method Description HttpRequest<T>
HttpRequest. basicAuthentication(Buffer id, Buffer password)
io.smallrye.mutiny.Uni<HttpResponse<T>>
HttpRequest. sendBuffer(Buffer body)
LikeHttpRequest.send()
but with an HTTP requestbody
buffer.HttpResponse<T>
HttpRequest. sendBufferAndAwait(Buffer body)
Blocking variant ofHttpRequest.sendBuffer(io.vertx.mutiny.core.buffer.Buffer)
.void
HttpRequest. sendBufferAndForget(Buffer body)
Variant ofHttpRequest.sendBuffer(io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.Method parameters in io.vertx.mutiny.ext.web.client with type arguments of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<HttpResponse<T>>
HttpRequest. sendStream(ReadStream<Buffer> body)
LikeHttpRequest.send()
but with an HTTP requestbody
stream.io.smallrye.mutiny.Uni<HttpResponse<T>>
HttpRequest. sendStream(Flow.Publisher<Buffer> body)
LikeHttpRequest.send()
but with an HTTP requestbody
stream.HttpResponse<T>
HttpRequest. sendStreamAndAwait(ReadStream<Buffer> body)
Blocking variant ofHttpRequest.sendStream(io.vertx.mutiny.core.streams.ReadStream)
.HttpResponse<T>
HttpRequest. sendStreamAndAwait(Flow.Publisher<Buffer> body)
Blocking variant ofio.vertx.mutiny.ext.web.client.HttpRequest#sendStream(Flow$Publisher)
.void
HttpRequest. sendStreamAndForget(ReadStream<Buffer> body)
Variant ofHttpRequest.sendStream(io.vertx.mutiny.core.streams.ReadStream)
that ignores the result of the operation.void
HttpRequest. sendStreamAndForget(Flow.Publisher<Buffer> body)
Variant ofio.vertx.mutiny.ext.web.client.HttpRequest#sendStream(Flow$Publisher)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.ext.web.client.predicate
Methods in io.vertx.mutiny.ext.web.client.predicate that return types with arguments of type Buffer Modifier and Type Method Description HttpResponse<Buffer>
ResponsePredicateResult. response()
Deprecated. -
Uses of Buffer in io.vertx.mutiny.ext.web.codec
Methods in io.vertx.mutiny.ext.web.codec that return types with arguments of type Buffer Modifier and Type Method Description static BodyCodec<Buffer>
BodyCodec. buffer()
Method parameters in io.vertx.mutiny.ext.web.codec with type arguments of type Buffer Modifier and Type Method Description static <T> BodyCodec<T>
BodyCodec. create(Function<Buffer,T> decode)
static BodyCodec<Void>
BodyCodec. pipe(WriteStream<Buffer> stream)
static BodyCodec<Void>
BodyCodec. pipe(WriteStream<Buffer> stream, boolean close)
-
Uses of Buffer in io.vertx.mutiny.ext.web.common.template
Methods in io.vertx.mutiny.ext.web.common.template that return Buffer Modifier and Type Method Description Buffer
TemplateEngine. renderAndAwait(io.vertx.core.json.JsonObject context, String templateFileName)
Blocking variant ofTemplateEngine.render(JsonObject,String)
.Buffer
TemplateEngine. renderAndAwait(Map<String,Object> context, String templateFileName)
Blocking variant ofTemplateEngine.render(Map,String)
.Methods in io.vertx.mutiny.ext.web.common.template that return types with arguments of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Buffer>
TemplateEngine. render(io.vertx.core.json.JsonObject context, String templateFileName)
Render the template.io.smallrye.mutiny.Uni<Buffer>
TemplateEngine. render(Map<String,Object> context, String templateFileName)
Render the template. -
Uses of Buffer in io.vertx.mutiny.ext.web.handler.sockjs
Methods in io.vertx.mutiny.ext.web.handler.sockjs that return types with arguments of type Buffer Modifier and Type Method Description Pipe<Buffer>
SockJSSocket. pipe()
Iterable<Buffer>
SockJSSocket. toBlockingIterable()
Stream<Buffer>
SockJSSocket. toBlockingStream()
io.smallrye.mutiny.Multi<Buffer>
SockJSSocket. toMulti()
WriteStreamSubscriber<Buffer>
SockJSSocket. toSubscriber()
Methods in io.vertx.mutiny.ext.web.handler.sockjs with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
SockJSSocket. end(Buffer data)
Void
SockJSSocket. endAndAwait(Buffer data)
void
SockJSSocket. endAndForget(Buffer data)
io.smallrye.mutiny.Uni<Void>
SockJSSocket. write(Buffer data)
Void
SockJSSocket. writeAndAwait(Buffer data)
void
SockJSSocket. writeAndForget(Buffer data)
Method parameters in io.vertx.mutiny.ext.web.handler.sockjs with type arguments of type Buffer Modifier and Type Method Description SockJSSocket
SockJSSocket. handler(Consumer<Buffer> handler)
io.smallrye.mutiny.Uni<Void>
SockJSSocket. pipeTo(WriteStream<Buffer> dst)
Void
SockJSSocket. pipeToAndAwait(WriteStream<Buffer> dst)
void
SockJSSocket. pipeToAndForget(WriteStream<Buffer> dst)
-
Uses of Buffer in io.vertx.mutiny.ext.web.multipart
Methods in io.vertx.mutiny.ext.web.multipart that return Buffer Modifier and Type Method Description Buffer
FormDataPart. content()
Methods in io.vertx.mutiny.ext.web.multipart with parameters of type Buffer Modifier and Type Method Description MultipartForm
MultipartForm. binaryFileUpload(String name, String filename, Buffer content, String mediaType)
MultipartForm
MultipartForm. textFileUpload(String name, String filename, Buffer content, String mediaType)
-
Uses of Buffer in io.vertx.mutiny.ext.web.validation
Methods in io.vertx.mutiny.ext.web.validation that return Buffer Modifier and Type Method Description Buffer
RequestParameter. getBuffer()
-
Uses of Buffer in io.vertx.mutiny.httpproxy
Methods in io.vertx.mutiny.httpproxy that return types with arguments of type Buffer Modifier and Type Method Description ReadStream<Buffer>
Body. stream()
Methods in io.vertx.mutiny.httpproxy with parameters of type Buffer Modifier and Type Method Description static Body
Body. body(Buffer buffer)
Method parameters in io.vertx.mutiny.httpproxy with type arguments of type Buffer Modifier and Type Method Description static Body
Body. body(ReadStream<Buffer> stream)
static Body
Body. body(ReadStream<Buffer> stream, long len)
static Body
Body. body(Flow.Publisher<Buffer> stream)
static Body
Body. body(Flow.Publisher<Buffer> stream, long len)
-
Uses of Buffer in io.vertx.mutiny.kafka.client.producer
Methods in io.vertx.mutiny.kafka.client.producer that return Buffer Modifier and Type Method Description Buffer
KafkaHeader. value()
Methods in io.vertx.mutiny.kafka.client.producer with parameters of type Buffer Modifier and Type Method Description KafkaProducerRecord<K,V>
KafkaProducerRecord. addHeader(String key, Buffer value)
static KafkaHeader
KafkaHeader. header(String key, Buffer value)
-
Uses of Buffer in io.vertx.mutiny.mqtt
Methods in io.vertx.mutiny.mqtt with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Integer>
MqttClient. publish(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Sends the PUBLISH message to the remote MQTT serverio.smallrye.mutiny.Uni<Integer>
MqttEndpoint. publish(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Sends the PUBLISH message to the remote MQTT serverio.smallrye.mutiny.Uni<Integer>
MqttEndpoint. publish(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId)
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageIdio.smallrye.mutiny.Uni<Integer>
MqttEndpoint. publish(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId, io.netty.handler.codec.mqtt.MqttProperties properties)
Sends the PUBLISH message to the remote MQTT server explicitly specifying the messageIdInteger
MqttClient. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Integer
MqttEndpoint. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Integer
MqttEndpoint. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId)
Integer
MqttEndpoint. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId, io.netty.handler.codec.mqtt.MqttProperties properties)
MqttClient
MqttClient. publishAndForget(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Variant ofMqttClient.publish(String,io.vertx.mutiny.core.buffer.Buffer,MqttQoS,boolean,boolean)
that ignores the result of the operation.MqttEndpoint
MqttEndpoint. publishAndForget(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)
Variant ofMqttEndpoint.publish(String,io.vertx.mutiny.core.buffer.Buffer,MqttQoS,boolean,boolean)
that ignores the result of the operation.MqttEndpoint
MqttEndpoint. publishAndForget(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId)
Variant ofMqttEndpoint.publish(String,io.vertx.mutiny.core.buffer.Buffer,MqttQoS,boolean,boolean,int)
that ignores the result of the operation.MqttEndpoint
MqttEndpoint. publishAndForget(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId, io.netty.handler.codec.mqtt.MqttProperties properties)
Variant ofMqttEndpoint.publish(String,io.vertx.mutiny.core.buffer.Buffer,MqttQoS,boolean,boolean,int,MqttProperties)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.mqtt.messages
Methods in io.vertx.mutiny.mqtt.messages that return Buffer Modifier and Type Method Description Buffer
MqttPublishMessage. payload()
-
Uses of Buffer in io.vertx.mutiny.rabbitmq
Methods in io.vertx.mutiny.rabbitmq that return Buffer Modifier and Type Method Description Buffer
RabbitMQMessage. body()
Methods in io.vertx.mutiny.rabbitmq with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<Void>
RabbitMQClient. basicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Publish a message.io.smallrye.mutiny.Uni<Void>
RabbitMQClient. basicPublish(String exchange, String routingKey, Buffer body)
Publish a message.Void
RabbitMQClient. basicPublishAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Void
RabbitMQClient. basicPublishAndAwait(String exchange, String routingKey, Buffer body)
Blocking variant ofRabbitMQClient.basicPublish(String,String,io.vertx.mutiny.core.buffer.Buffer)
.void
RabbitMQClient. basicPublishAndForget(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Variant ofRabbitMQClient.basicPublish(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.void
RabbitMQClient. basicPublishAndForget(String exchange, String routingKey, Buffer body)
Variant ofRabbitMQClient.basicPublish(String,String,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
RabbitMQClient. basicPublishWithDeliveryTag(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Consumer<Long> deliveryTagHandler)
Publish a message.Void
RabbitMQClient. basicPublishWithDeliveryTagAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Consumer<Long> deliveryTagHandler)
void
RabbitMQClient. basicPublishWithDeliveryTagAndForget(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Consumer<Long> deliveryTagHandler)
Variant ofRabbitMQClient.basicPublishWithDeliveryTag(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer,Consumer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>
RabbitMQPublisher. publish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Publish a message.Void
RabbitMQPublisher. publishAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
void
RabbitMQPublisher. publishAndForget(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Variant ofRabbitMQPublisher.publish(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation.io.smallrye.mutiny.Uni<Long>
RabbitMQPublisher. publishConfirm(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Publish a message and complete when publish confirm has returned.Long
RabbitMQPublisher. publishConfirmAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
void
RabbitMQPublisher. publishConfirmAndForget(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
Variant ofRabbitMQPublisher.publishConfirm(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer)
that ignores the result of the operation. -
Uses of Buffer in io.vertx.mutiny.redis.client
Methods in io.vertx.mutiny.redis.client that return Buffer Modifier and Type Method Description Buffer
Response. toBuffer()
Methods in io.vertx.mutiny.redis.client with parameters of type Buffer Modifier and Type Method Description Request
Request. arg(Buffer arg)
-
Uses of Buffer in io.vertx.mutiny.sqlclient
Methods in io.vertx.mutiny.sqlclient that return Buffer Modifier and Type Method Description Buffer
Row. getBuffer(String column)
Buffer
Tuple. getBuffer(int pos)
Methods in io.vertx.mutiny.sqlclient with parameters of type Buffer Modifier and Type Method Description Tuple
Tuple. addBuffer(Buffer value)
-