Uses of Class
io.vertx.mutiny.core.buffer.Buffer
- 
- 
Uses of Buffer in io.vertx.mutiny.amqpMethods in io.vertx.mutiny.amqp that return Buffer Modifier and Type Method Description BufferAmqpMessage. bodyAsBinary()Methods in io.vertx.mutiny.amqp with parameters of type Buffer Modifier and Type Method Description AmqpMessageBuilderAmqpMessageBuilder. withBufferAsBody(Buffer buffer)
- 
Uses of Buffer in io.vertx.mutiny.core.bufferFields in io.vertx.mutiny.core.buffer with type parameters of type Buffer Modifier and Type Field Description static TypeArg<Buffer>Buffer. __TYPE_ARGMethods in io.vertx.mutiny.core.buffer that return Buffer Modifier and Type Method Description BufferBuffer. appendBuffer(Buffer buff)BufferBuffer. appendBuffer(Buffer buff, int offset, int len)BufferBuffer. appendByte(byte b)BufferBuffer. appendBytes(byte[] bytes)BufferBuffer. appendBytes(byte[] bytes, int offset, int len)BufferBuffer. appendDouble(double d)BufferBuffer. appendFloat(float f)BufferBuffer. appendInt(int i)BufferBuffer. appendIntLE(int i)BufferBuffer. appendLong(long l)BufferBuffer. appendLongLE(long l)BufferBuffer. appendMedium(int i)BufferBuffer. appendMediumLE(int i)BufferBuffer. appendShort(short s)BufferBuffer. appendShortLE(short s)BufferBuffer. appendString(String str)BufferBuffer. appendString(String str, String enc)BufferBuffer. appendUnsignedByte(short b)BufferBuffer. appendUnsignedInt(long i)BufferBuffer. appendUnsignedIntLE(long i)BufferBuffer. appendUnsignedShort(int s)BufferBuffer. appendUnsignedShortLE(int s)static BufferBuffer. buffer()static BufferBuffer. buffer(byte[] bytes)static BufferBuffer. buffer(int initialSizeHint)static BufferBuffer. buffer(io.netty.buffer.ByteBuf byteBuf)static BufferBuffer. buffer(String string)static BufferBuffer. buffer(String string, String enc)BufferBuffer. copy()BufferBuffer. getBuffer(int start, int end)BufferBuffer. getBytes(byte[] dst)BufferBuffer. getBytes(byte[] dst, int dstIndex)BufferBuffer. getBytes(int start, int end, byte[] dst)BufferBuffer. getBytes(int start, int end, byte[] dst, int dstIndex)static BufferBuffer. newInstance(io.vertx.core.buffer.Buffer arg)BufferBuffer. setBuffer(int pos, Buffer b)BufferBuffer. setBuffer(int pos, Buffer b, int offset, int len)BufferBuffer. setByte(int pos, byte b)BufferBuffer. setBytes(int pos, byte[] b)BufferBuffer. setBytes(int pos, byte[] b, int offset, int len)BufferBuffer. setBytes(int pos, ByteBuffer b)BufferBuffer. setDouble(int pos, double d)BufferBuffer. setFloat(int pos, float f)BufferBuffer. setInt(int pos, int i)BufferBuffer. setIntLE(int pos, int i)BufferBuffer. setLong(int pos, long l)BufferBuffer. setLongLE(int pos, long l)BufferBuffer. setMedium(int pos, int i)BufferBuffer. setMediumLE(int pos, int i)BufferBuffer. setShort(int pos, short s)BufferBuffer. setShortLE(int pos, short s)BufferBuffer. setString(int pos, String str)BufferBuffer. setString(int pos, String str, String enc)BufferBuffer. setUnsignedByte(int pos, short b)BufferBuffer. setUnsignedInt(int pos, long i)BufferBuffer. setUnsignedIntLE(int pos, long i)BufferBuffer. setUnsignedShort(int pos, int s)BufferBuffer. setUnsignedShortLE(int pos, int s)BufferBuffer. slice()BufferBuffer. slice(int start, int end)Methods in io.vertx.mutiny.core.buffer with parameters of type Buffer Modifier and Type Method Description BufferBuffer. appendBuffer(Buffer buff)BufferBuffer. appendBuffer(Buffer buff, int offset, int len)BufferBuffer. setBuffer(int pos, Buffer b)BufferBuffer. setBuffer(int pos, Buffer b, int offset, int len)
- 
Uses of Buffer in io.vertx.mutiny.core.datagramMethods in io.vertx.mutiny.core.datagram that return Buffer Modifier and Type Method Description BufferDatagramPacket. 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 givenBufferto theSocketAddress.VoidDatagramSocket. sendAndAwait(Buffer packet, int port, String host)Blocking variant ofDatagramSocket.send(io.vertx.mutiny.core.buffer.Buffer,int,String).DatagramSocketDatagramSocket. 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.fileMethods in io.vertx.mutiny.core.file that return Buffer Modifier and Type Method Description BufferAsyncFile. readAndAwait(Buffer buffer, int offset, long position, int length)Blocking variant ofAsyncFile.read(io.vertx.mutiny.core.buffer.Buffer,int,long,int).BufferFileSystem. readFileAndAwait(String path)Blocking variant ofFileSystem.readFile(String).BufferFileSystem. 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)Readslengthbytes of data from the file at positionpositionin the file, asynchronously.io.smallrye.mutiny.Uni<Buffer>FileSystem. readFile(String path)Reads the entire file as represented by the pathpathas 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 anhandlercalled when the operation completesVoidAsyncFile. endAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer).voidAsyncFile. 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)Readslengthbytes of data from the file at positionpositionin the file, asynchronously.BufferAsyncFile. readAndAwait(Buffer buffer, int offset, long position, int length)Blocking variant ofAsyncFile.read(io.vertx.mutiny.core.buffer.Buffer,int,long,int).AsyncFileAsyncFile. 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 anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>AsyncFile. write(Buffer buffer, long position)Write aBufferto the file at positionpositionin the file, asynchronously.VoidAsyncFile. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).VoidAsyncFile. writeAndAwait(Buffer buffer, long position)Blocking variant ofAsyncFile.write(io.vertx.mutiny.core.buffer.Buffer,long).voidAsyncFile. writeAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidAsyncFile. 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 datato the file represented by the pathpath, asynchronously.VoidFileSystem. writeFileAndAwait(String path, Buffer data)Blocking variant ofFileSystem.writeFile(String,io.vertx.mutiny.core.buffer.Buffer).FileSystemFileSystem. writeFileAndForget(String path, Buffer data)Variant ofFileSystem.writeFile(String,io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.FileSystemFileSystem. writeFileBlocking(String path, Buffer data)Method parameters in io.vertx.mutiny.core.file with type arguments of type Buffer Modifier and Type Method Description AsyncFileAsyncFile. handler(Consumer<Buffer> handler)io.smallrye.mutiny.Uni<Void>AsyncFile. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.VoidAsyncFile. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) voidAsyncFile. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) 
- 
Uses of Buffer in io.vertx.mutiny.core.httpFields in io.vertx.mutiny.core.http with type parameters of type Buffer Modifier and Type Field Description static TypeArg<Buffer>WebSocketBase. TYPE_ARG_0Methods in io.vertx.mutiny.core.http that return Buffer Modifier and Type Method Description BufferWebSocketFrame. binaryData()BufferHttpClientResponse. bodyAndAwait()Blocking variant ofHttpClientResponse.body().BufferHttpServerRequest. bodyAndAwait()Blocking variant ofHttpServerRequest.body().BufferHttpFrame. payload()BufferHttpConnection. 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 anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Buffer>HttpServerRequest. body()Same asHttpServerRequest.body()but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Buffer>HttpConnection. ping(Buffer data)Send a frame to the remote endpoint.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>HttpClientResponse. toBlockingIterable()Iterable<Buffer>HttpServerFileUpload. toBlockingIterable()Iterable<Buffer>HttpServerRequest. toBlockingIterable()Iterable<Buffer>ServerWebSocket. toBlockingIterable()Iterable<Buffer>WebSocket. toBlockingIterable()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>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>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 WebSocketFrameWebSocketFrame. binaryFrame(Buffer data, boolean isFinal)static WebSocketFrameWebSocketFrame. continuationFrame(Buffer data, boolean isFinal)io.smallrye.mutiny.Uni<Void>HttpClientRequest. end(Buffer chunk)Same asHttpClientRequest.end(java.lang.String)but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>HttpServerResponse. end(Buffer chunk)Same asHttpServerResponse.end()but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>ServerWebSocket. end(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>WebSocket. end(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>WebSocketBase. end(Buffer data)Same as but with anhandlercalled when the operation completesVoidHttpClientRequest. endAndAwait(Buffer chunk)Blocking variant ofHttpClientRequest.end(io.vertx.mutiny.core.buffer.Buffer).VoidHttpServerResponse. endAndAwait(Buffer chunk)Blocking variant ofHttpServerResponse.end(io.vertx.mutiny.core.buffer.Buffer).VoidServerWebSocket. endAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocket. endAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocketBase. endAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer).voidHttpClientRequest. endAndForget(Buffer chunk)Variant ofHttpClientRequest.end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidHttpServerResponse. endAndForget(Buffer chunk)Variant ofHttpServerResponse.end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidServerWebSocket. endAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidWebSocket. endAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidWebSocketBase. endAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.HttpConnectionHttpConnection. goAway(long errorCode, int lastStreamId, Buffer debugData)io.smallrye.mutiny.Uni<Buffer>HttpConnection. ping(Buffer data)Send a frame to the remote endpoint.BufferHttpConnection. pingAndAwait(Buffer data)Blocking variant ofHttpConnection.ping(io.vertx.mutiny.core.buffer.Buffer).HttpConnectionHttpConnection. pingAndForget(Buffer data)Variant ofHttpConnection.ping(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.static WebSocketFrameWebSocketFrame. pingFrame(Buffer data)static WebSocketFrameWebSocketFrame. 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.HttpClientResponseHttpClientRequest. sendAndAwait(Buffer body)Blocking variant ofHttpClientRequest.send(io.vertx.mutiny.core.buffer.Buffer).VoidHttpServerResponse. sendAndAwait(Buffer body)Blocking variant ofHttpServerResponse.send(io.vertx.mutiny.core.buffer.Buffer).voidHttpClientRequest. sendAndForget(Buffer body)Variant ofHttpClientRequest.send(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidHttpServerResponse. sendAndForget(Buffer body)Variant ofHttpServerResponse.send(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>HttpClientRequest. write(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>HttpServerResponse. write(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>ServerWebSocket. write(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>WebSocket. write(Buffer data)Same as but with anhandlercalled when the operation completesio.smallrye.mutiny.Uni<Void>WebSocketBase. write(Buffer data)Same as but with anhandlercalled when the operation completesVoidHttpClientRequest. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).VoidHttpServerResponse. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).VoidServerWebSocket. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocket. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocketBase. writeAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).voidHttpClientRequest. writeAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidHttpServerResponse. writeAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidServerWebSocket. writeAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidWebSocket. writeAndForget(Buffer data)Variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidWebSocketBase. 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>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 anhandlercalled when the operation completesVoidServerWebSocket. writeBinaryMessageAndAwait(Buffer data)VoidWebSocket. writeBinaryMessageAndAwait(Buffer data)VoidWebSocketBase. writeBinaryMessageAndAwait(Buffer data)Blocking variant ofWebSocketBase.writeBinaryMessage(io.vertx.mutiny.core.buffer.Buffer).ServerWebSocketServerWebSocket. writeBinaryMessageAndForget(Buffer data)WebSocketWebSocket. writeBinaryMessageAndForget(Buffer data)WebSocketBaseWebSocketBase. writeBinaryMessageAndForget(Buffer data)Variant ofWebSocketBase.writeBinaryMessage(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.HttpClientRequestHttpClientRequest. writeCustomFrame(int type, int flags, Buffer payload)HttpServerResponseHttpServerResponse. writeCustomFrame(int type, int flags, Buffer payload)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 anhandlercalled when the operation completesVoidServerWebSocket. writeFinalBinaryFrameAndAwait(Buffer data)VoidWebSocket. writeFinalBinaryFrameAndAwait(Buffer data)VoidWebSocketBase. writeFinalBinaryFrameAndAwait(Buffer data)Blocking variant ofWebSocketBase.writeFinalBinaryFrame(io.vertx.mutiny.core.buffer.Buffer).ServerWebSocketServerWebSocket. writeFinalBinaryFrameAndForget(Buffer data)WebSocketWebSocket. writeFinalBinaryFrameAndForget(Buffer data)WebSocketBaseWebSocketBase. writeFinalBinaryFrameAndForget(Buffer data)Variant ofWebSocketBase.writeFinalBinaryFrame(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>ServerWebSocket. writePing(Buffer data)Writes a ping frame to the connection.io.smallrye.mutiny.Uni<Void>WebSocket. writePing(Buffer data)Writes a ping frame to the connection.io.smallrye.mutiny.Uni<Void>WebSocketBase. writePing(Buffer data)Writes a ping frame to the connection.VoidServerWebSocket. writePingAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocket. writePingAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocketBase. writePingAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer).WebSocketBaseServerWebSocket. writePingAndForget(Buffer data)Variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.WebSocketBaseWebSocket. writePingAndForget(Buffer data)Variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.WebSocketBaseWebSocketBase. writePingAndForget(Buffer data)Variant ofWebSocketBase.writePing(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.io.smallrye.mutiny.Uni<Void>ServerWebSocket. writePong(Buffer data)Writes a pong frame to the connection.io.smallrye.mutiny.Uni<Void>WebSocket. writePong(Buffer data)Writes a pong frame to the connection.io.smallrye.mutiny.Uni<Void>WebSocketBase. writePong(Buffer data)Writes a pong frame to the connection.VoidServerWebSocket. writePongAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocket. writePongAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer).VoidWebSocketBase. writePongAndAwait(Buffer data)Blocking variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer).WebSocketBaseServerWebSocket. writePongAndForget(Buffer data)Variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.WebSocketBaseWebSocket. writePongAndForget(Buffer data)Variant ofWebSocketBase.writePong(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.WebSocketBaseWebSocketBase. 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 WebSocketBaseServerWebSocket. binaryMessageHandler(Consumer<Buffer> handler)WebSocketBaseWebSocket. binaryMessageHandler(Consumer<Buffer> handler)WebSocketBaseWebSocketBase. binaryMessageHandler(Consumer<Buffer> handler)HttpClientResponseHttpClientResponse. bodyHandler(Consumer<Buffer> bodyHandler)HttpServerRequestHttpServerRequest. bodyHandler(Consumer<Buffer> bodyHandler)HttpClientResponseHttpClientResponse. handler(Consumer<Buffer> handler)HttpServerFileUploadHttpServerFileUpload. handler(Consumer<Buffer> handler)HttpServerRequestHttpServerRequest. handler(Consumer<Buffer> handler)ServerWebSocketServerWebSocket. handler(Consumer<Buffer> handler)WebSocketWebSocket. handler(Consumer<Buffer> handler)WebSocketBaseWebSocketBase. handler(Consumer<Buffer> handler)HttpConnectionHttpConnection. pingHandler(Consumer<Buffer> handler)io.smallrye.mutiny.Uni<Void>HttpClientResponse. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.io.smallrye.mutiny.Uni<Void>HttpServerFileUpload. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.io.smallrye.mutiny.Uni<Void>HttpServerRequest. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.io.smallrye.mutiny.Uni<Void>ServerWebSocket. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.io.smallrye.mutiny.Uni<Void>WebSocket. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.io.smallrye.mutiny.Uni<Void>WebSocketBase. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.VoidHttpClientResponse. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) VoidHttpServerFileUpload. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) VoidHttpServerRequest. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) VoidServerWebSocket. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) VoidWebSocket. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) VoidWebSocketBase. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) voidHttpClientResponse. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidHttpServerFileUpload. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidHttpServerRequest. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidServerWebSocket. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidWebSocket. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidWebSocketBase. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) WebSocketBaseServerWebSocket. pongHandler(Consumer<Buffer> handler)WebSocketBaseWebSocket. pongHandler(Consumer<Buffer> handler)WebSocketBaseWebSocketBase. 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(org.reactivestreams.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(org.reactivestreams.Publisher<Buffer> body)Send the request with a streambody.HttpClientResponseHttpClientRequest. sendAndAwait(ReadStream<Buffer> body)Blocking variant ofio.vertx.mutiny.core.http.HttpClientRequest#send(io.vertx.mutiny.core.streams.ReadStream.) HttpClientResponseHttpClientRequest. sendAndAwait(org.reactivestreams.Publisher<Buffer> body)Blocking variant ofHttpClientRequest.send(Publisher<Buffer>).VoidHttpServerResponse. sendAndAwait(ReadStream<Buffer> body)Blocking variant ofio.vertx.mutiny.core.http.HttpServerResponse#send(io.vertx.mutiny.core.streams.ReadStream.) VoidHttpServerResponse. sendAndAwait(org.reactivestreams.Publisher<Buffer> body)Blocking variant ofHttpServerResponse.send(Publisher<Buffer>).voidHttpClientRequest. sendAndForget(ReadStream<Buffer> body)Variant ofio.vertx.mutiny.core.http.HttpClientRequest#send(io.vertx.mutiny.core.streams.ReadStreamthat ignores the result of the operation.) voidHttpClientRequest. sendAndForget(org.reactivestreams.Publisher<Buffer> body)Variant ofHttpClientRequest.send(Publisher<Buffer>)that ignores the result of the operation.voidHttpServerResponse. sendAndForget(ReadStream<Buffer> body)Variant ofio.vertx.mutiny.core.http.HttpServerResponse#send(io.vertx.mutiny.core.streams.ReadStreamthat ignores the result of the operation.) voidHttpServerResponse. sendAndForget(org.reactivestreams.Publisher<Buffer> body)Variant ofHttpServerResponse.send(Publisher<Buffer>)that ignores the result of the operation.
- 
Uses of Buffer in io.vertx.mutiny.core.netMethods 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 anhandlercalled when the operation completesVoidNetSocket. endAndAwait(Buffer data)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#end(io.vertx.mutiny.core.buffer.Buffer).voidNetSocket. 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 anhandlercalled when the message has been written or failed to be written.VoidNetSocket. writeAndAwait(Buffer message)Blocking variant ofio.vertx.mutiny.core.streams.WriteStream#write(io.vertx.mutiny.core.buffer.Buffer).voidNetSocket. 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 NetSocketNetSocket. handler(Consumer<Buffer> handler)io.smallrye.mutiny.Uni<Void>NetSocket. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.VoidNetSocket. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) voidNetSocket. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) 
- 
Uses of Buffer in io.vertx.mutiny.core.parsetoolsMethods in io.vertx.mutiny.core.parsetools that return Buffer Modifier and Type Method Description BufferJsonEvent. 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 voidJsonParser. accept(Buffer item)voidRecordParser. accept(Buffer item)voidRecordParser. delimitedMode(Buffer delim)voidJsonParser. handle(Buffer event)voidRecordParser. handle(Buffer buffer)static RecordParserRecordParser. newDelimited(Buffer delim)static RecordParserRecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)static RecordParserRecordParser. newDelimited(Buffer delim, Consumer<Buffer> output)static RecordParserRecordParser. newDelimited(Buffer delim, org.reactivestreams.Publisher<Buffer> stream)JsonParserJsonParser. write(Buffer buffer)Method parameters in io.vertx.mutiny.core.parsetools with type arguments of type Buffer Modifier and Type Method Description RecordParserRecordParser. handler(Consumer<Buffer> handler)static RecordParserRecordParser. newDelimited(Buffer delim, ReadStream<Buffer> stream)static RecordParserRecordParser. newDelimited(Buffer delim, Consumer<Buffer> output)static RecordParserRecordParser. newDelimited(Buffer delim, org.reactivestreams.Publisher<Buffer> stream)static RecordParserRecordParser. newDelimited(String delim, ReadStream<Buffer> stream)static RecordParserRecordParser. newDelimited(String delim, Consumer<Buffer> output)static RecordParserRecordParser. newDelimited(String delim, org.reactivestreams.Publisher<Buffer> stream)static RecordParserRecordParser. newFixed(int size, ReadStream<Buffer> stream)static RecordParserRecordParser. newFixed(int size, Consumer<Buffer> output)static RecordParserRecordParser. newFixed(int size, org.reactivestreams.Publisher<Buffer> stream)static JsonParserJsonParser. newParser(ReadStream<Buffer> stream)static JsonParserJsonParser. newParser(org.reactivestreams.Publisher<Buffer> stream)io.smallrye.mutiny.Uni<Void>RecordParser. pipeTo(WriteStream<Buffer> dst)Pipe thisReadStreamto theWriteStream.VoidRecordParser. pipeToAndAwait(WriteStream<Buffer> dst)Blocking variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStream.) voidRecordParser. pipeToAndForget(WriteStream<Buffer> dst)Variant ofio.vertx.mutiny.core.streams.ReadStream#pipeTo(io.vertx.mutiny.core.streams.WriteStreamthat ignores the result of the operation.) voidRecordParser. setOutput(Consumer<Buffer> output)
- 
Uses of Buffer in io.vertx.mutiny.ext.auth.oauth2Methods in io.vertx.mutiny.ext.auth.oauth2 that return Buffer Modifier and Type Method Description BufferOAuth2Response. body()Deprecated.Methods in io.vertx.mutiny.ext.auth.oauth2 with parameters of type Buffer Modifier and Type Method Description io.smallrye.mutiny.Uni<OAuth2Response>AccessToken. fetch(io.vertx.core.http.HttpMethod method, String resource, io.vertx.core.json.JsonObject headers, Buffer payload)Fetches a JSON resource using this Access Token.OAuth2ResponseAccessToken. fetchAndAwait(io.vertx.core.http.HttpMethod method, String resource, io.vertx.core.json.JsonObject headers, Buffer payload)Blocking variant ofAccessToken.fetch(HttpMethod,String,JsonObject,io.vertx.mutiny.core.buffer.Buffer).AccessTokenAccessToken. fetchAndForget(io.vertx.core.http.HttpMethod method, String resource, io.vertx.core.json.JsonObject headers, Buffer payload)Variant ofAccessToken.fetch(HttpMethod,String,JsonObject,io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.
- 
Uses of Buffer in io.vertx.mutiny.ext.mailMethods in io.vertx.mutiny.ext.mail that return Buffer Modifier and Type Method Description BufferMailAttachment. 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 MailAttachmentMailAttachment. setData(Buffer data)Method parameters in io.vertx.mutiny.ext.mail with type arguments of type Buffer Modifier and Type Method Description MailAttachmentMailAttachment. setStream(ReadStream<Buffer> stream)MailAttachmentMailAttachment. setStream(org.reactivestreams.Publisher<Buffer> stream)
- 
Uses of Buffer in io.vertx.mutiny.ext.mongoMethod 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)LongMongoGridFsClient. downloadByFileNameAndAwait(WriteStream<Buffer> stream, String fileName)MongoGridFsClientMongoGridFsClient. downloadByFileNameAndForget(WriteStream<Buffer> stream, String fileName)io.smallrye.mutiny.Uni<Long>MongoGridFsClient. downloadByFileNameWithOptions(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)LongMongoGridFsClient. downloadByFileNameWithOptionsAndAwait(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)MongoGridFsClientMongoGridFsClient. downloadByFileNameWithOptionsAndForget(WriteStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsDownloadOptions options)io.smallrye.mutiny.Uni<Long>MongoGridFsClient. downloadById(WriteStream<Buffer> stream, String id)LongMongoGridFsClient. downloadByIdAndAwait(WriteStream<Buffer> stream, String id)MongoGridFsClientMongoGridFsClient. 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(org.reactivestreams.Publisher<Buffer> stream, String fileName)StringMongoGridFsClient. uploadByFileNameAndAwait(ReadStream<Buffer> stream, String fileName)StringMongoGridFsClient. uploadByFileNameAndAwait(org.reactivestreams.Publisher<Buffer> stream, String fileName)MongoGridFsClientMongoGridFsClient. uploadByFileNameAndForget(ReadStream<Buffer> stream, String fileName)MongoGridFsClientMongoGridFsClient. uploadByFileNameAndForget(org.reactivestreams.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(org.reactivestreams.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)StringMongoGridFsClient. uploadByFileNameWithOptionsAndAwait(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)StringMongoGridFsClient. uploadByFileNameWithOptionsAndAwait(org.reactivestreams.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)MongoGridFsClientMongoGridFsClient. uploadByFileNameWithOptionsAndForget(ReadStream<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)MongoGridFsClientMongoGridFsClient. uploadByFileNameWithOptionsAndForget(org.reactivestreams.Publisher<Buffer> stream, String fileName, io.vertx.ext.mongo.GridFsUploadOptions options)
- 
Uses of Buffer in io.vertx.mutiny.ext.stompMethods 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 aSENDframe 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 aSENDframe 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 aSENDframe to the server.io.vertx.ext.stomp.FrameStompClientConnection. sendAndAwait(String destination, Buffer body)Blocking variant ofStompClientConnection.send(String,io.vertx.mutiny.core.buffer.Buffer).io.vertx.ext.stomp.FrameStompClientConnection. sendAndAwait(String destination, Map<String,String> headers, Buffer body)Blocking variant ofio.vertx.mutiny.ext.stomp.StompClientConnection#send(String,Map.,io.vertx.mutiny.core.buffer.Buffer) io.vertx.ext.stomp.FrameStompClientConnection. sendAndAwait(Map<String,String> headers, Buffer body)Blocking variant ofio.vertx.mutiny.ext.stomp.StompClientConnection#send(Map.,io.vertx.mutiny.core.buffer.Buffer) StompClientConnectionStompClientConnection. sendAndForget(String destination, Buffer body)Variant ofStompClientConnection.send(String,io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.StompClientConnectionStompClientConnection. sendAndForget(String destination, Map<String,String> headers, Buffer body)Variant ofio.vertx.mutiny.ext.stomp.StompClientConnection#send(String,Mapthat ignores the result of the operation.,io.vertx.mutiny.core.buffer.Buffer) StompClientConnectionStompClientConnection. sendAndForget(Map<String,String> headers, Buffer body)Variant ofio.vertx.mutiny.ext.stomp.StompClientConnection#send(Mapthat ignores the result of the operation.,io.vertx.mutiny.core.buffer.Buffer) StompServerConnectionStompServerConnection. write(Buffer buffer)
- 
Uses of Buffer in io.vertx.mutiny.ext.webMethods in io.vertx.mutiny.ext.web that return Buffer Modifier and Type Method Description BufferRoutingContext. getBody()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)VoidRoutingContext. endAndAwait(Buffer buffer)Blocking variant ofRoutingContext.end(io.vertx.mutiny.core.buffer.Buffer).RoutingContextRoutingContext. endAndForget(Buffer buffer)Variant ofRoutingContext.end(io.vertx.mutiny.core.buffer.Buffer)that ignores the result of the operation.voidRoutingContext. setBody(Buffer body)
- 
Uses of Buffer in io.vertx.mutiny.ext.web.clientMethods in io.vertx.mutiny.ext.web.client that return Buffer Modifier and Type Method Description BufferHttpResponse. 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, String requestURI)HttpRequest<Buffer>WebClient. delete(String requestURI)HttpRequest<Buffer>WebClient. delete(String host, String requestURI)HttpRequest<Buffer>WebClient. deleteAbs(String absoluteURI)HttpRequest<Buffer>WebClient. get(int port, String host, String requestURI)HttpRequest<Buffer>WebClient. get(String requestURI)HttpRequest<Buffer>WebClient. get(String host, String requestURI)HttpRequest<Buffer>WebClient. getAbs(String absoluteURI)HttpRequest<Buffer>WebClient. head(int port, String host, String requestURI)HttpRequest<Buffer>WebClient. head(String requestURI)HttpRequest<Buffer>WebClient. head(String host, String requestURI)HttpRequest<Buffer>WebClient. headAbs(String absoluteURI)HttpRequest<Buffer>WebClient. patch(int port, String host, String requestURI)HttpRequest<Buffer>WebClient. patch(String requestURI)HttpRequest<Buffer>WebClient. patch(String host, String requestURI)HttpRequest<Buffer>WebClient. patchAbs(String absoluteURI)HttpRequest<Buffer>WebClient. post(int port, String host, String requestURI)HttpRequest<Buffer>WebClient. post(String requestURI)HttpRequest<Buffer>WebClient. post(String host, String requestURI)HttpRequest<Buffer>WebClient. postAbs(String absoluteURI)HttpRequest<Buffer>WebClient. put(int port, String host, String requestURI)HttpRequest<Buffer>WebClient. put(String requestURI)HttpRequest<Buffer>WebClient. put(String host, String requestURI)HttpRequest<Buffer>WebClient. putAbs(String absoluteURI)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, 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, String 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, String 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, String 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 requestbodybuffer.HttpResponse<T>HttpRequest. sendBufferAndAwait(Buffer body)Blocking variant ofHttpRequest.sendBuffer(io.vertx.mutiny.core.buffer.Buffer).voidHttpRequest. 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 requestbodystream.io.smallrye.mutiny.Uni<HttpResponse<T>>HttpRequest. sendStream(org.reactivestreams.Publisher<Buffer> body)LikeHttpRequest.send()but with an HTTP requestbodystream.HttpResponse<T>HttpRequest. sendStreamAndAwait(ReadStream<Buffer> body)Blocking variant ofio.vertx.mutiny.ext.web.client.HttpRequest#sendStream(io.vertx.mutiny.core.streams.ReadStream.) HttpResponse<T>HttpRequest. sendStreamAndAwait(org.reactivestreams.Publisher<Buffer> body)Blocking variant ofHttpRequest.sendStream(Publisher<Buffer>).voidHttpRequest. sendStreamAndForget(ReadStream<Buffer> body)Variant ofio.vertx.mutiny.ext.web.client.HttpRequest#sendStream(io.vertx.mutiny.core.streams.ReadStreamthat ignores the result of the operation.) voidHttpRequest. sendStreamAndForget(org.reactivestreams.Publisher<Buffer> body)Variant ofHttpRequest.sendStream(Publisher<Buffer>)that ignores the result of the operation.
- 
Uses of Buffer in io.vertx.mutiny.ext.web.client.predicateMethods 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()
- 
Uses of Buffer in io.vertx.mutiny.ext.web.codecMethods 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.templateMethods in io.vertx.mutiny.ext.web.common.template that return Buffer Modifier and Type Method Description BufferTemplateEngine. renderAndAwait(io.vertx.core.json.JsonObject context, String templateFileName)Blocking variant ofTemplateEngine.render(JsonObject,String).BufferTemplateEngine. renderAndAwait(Map<String,Object> context, String templateFileName)Blocking variant ofio.vertx.mutiny.ext.web.common.template.TemplateEngine#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.sockjsMethods 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)VoidSockJSSocket. endAndAwait(Buffer data)voidSockJSSocket. endAndForget(Buffer data)io.smallrye.mutiny.Uni<Void>SockJSSocket. write(Buffer data)VoidSockJSSocket. writeAndAwait(Buffer data)voidSockJSSocket. writeAndForget(Buffer data)Method parameters in io.vertx.mutiny.ext.web.handler.sockjs with type arguments of type Buffer Modifier and Type Method Description SockJSSocketSockJSSocket. handler(Consumer<Buffer> handler)io.smallrye.mutiny.Uni<Void>SockJSSocket. pipeTo(WriteStream<Buffer> dst)VoidSockJSSocket. pipeToAndAwait(WriteStream<Buffer> dst)voidSockJSSocket. pipeToAndForget(WriteStream<Buffer> dst)
- 
Uses of Buffer in io.vertx.mutiny.ext.web.multipartMethods in io.vertx.mutiny.ext.web.multipart that return Buffer Modifier and Type Method Description BufferFormDataPart. content()Methods in io.vertx.mutiny.ext.web.multipart with parameters of type Buffer Modifier and Type Method Description MultipartFormMultipartForm. binaryFileUpload(String name, String filename, Buffer content, String mediaType)MultipartFormMultipartForm. textFileUpload(String name, String filename, Buffer content, String mediaType)
- 
Uses of Buffer in io.vertx.mutiny.ext.web.validationMethods in io.vertx.mutiny.ext.web.validation that return Buffer Modifier and Type Method Description BufferRequestParameter. getBuffer()
- 
Uses of Buffer in io.vertx.mutiny.kafka.client.producerMethods in io.vertx.mutiny.kafka.client.producer that return Buffer Modifier and Type Method Description BufferKafkaHeader. 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 KafkaHeaderKafkaHeader. header(String key, Buffer value)
- 
Uses of Buffer in io.vertx.mutiny.mqttMethods 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 messageIdIntegerMqttClient. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)IntegerMqttEndpoint. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain)IntegerMqttEndpoint. publishAndAwait(String topic, Buffer payload, io.netty.handler.codec.mqtt.MqttQoS qosLevel, boolean isDup, boolean isRetain, int messageId)MqttClientMqttClient. 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.MqttEndpointMqttEndpoint. 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.MqttEndpointMqttEndpoint. 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.
- 
Uses of Buffer in io.vertx.mutiny.mqtt.messagesMethods in io.vertx.mutiny.mqtt.messages that return Buffer Modifier and Type Method Description BufferMqttPublishMessage. payload()
- 
Uses of Buffer in io.vertx.mutiny.rabbitmqMethods in io.vertx.mutiny.rabbitmq that return Buffer Modifier and Type Method Description BufferRabbitMQMessage. 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.VoidRabbitMQClient. basicPublishAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)VoidRabbitMQClient. basicPublishAndAwait(String exchange, String routingKey, Buffer body)Blocking variant ofRabbitMQClient.basicPublish(String,String,io.vertx.mutiny.core.buffer.Buffer).voidRabbitMQClient. 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.voidRabbitMQClient. 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.VoidRabbitMQClient. basicPublishWithDeliveryTagAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Consumer<Long> deliveryTagHandler)Blocking variant ofio.vertx.mutiny.rabbitmq.RabbitMQClient#basicPublishWithDeliveryTag(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer,Consumer.) voidRabbitMQClient. basicPublishWithDeliveryTagAndForget(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Consumer<Long> deliveryTagHandler)Variant ofio.vertx.mutiny.rabbitmq.RabbitMQClient#basicPublishWithDeliveryTag(String,String,BasicProperties,io.vertx.mutiny.core.buffer.Buffer,Consumerthat 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.VoidRabbitMQPublisher. publishAndAwait(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)voidRabbitMQPublisher. 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.
- 
Uses of Buffer in io.vertx.mutiny.redis.clientMethods in io.vertx.mutiny.redis.client that return Buffer Modifier and Type Method Description BufferResponse. toBuffer()Methods in io.vertx.mutiny.redis.client with parameters of type Buffer Modifier and Type Method Description RequestRequest. arg(Buffer arg)
- 
Uses of Buffer in io.vertx.mutiny.sqlclientMethods in io.vertx.mutiny.sqlclient that return Buffer Modifier and Type Method Description BufferRow. getBuffer(String column)BufferTuple. getBuffer(int pos)Methods in io.vertx.mutiny.sqlclient with parameters of type Buffer Modifier and Type Method Description TupleTuple. addBuffer(Buffer value)
 
-