Package | Description |
---|---|
org.springframework.core.codec | |
org.springframework.core.io.buffer |
Generic abstraction for working with byte buffer implementations.
|
org.springframework.http |
Contains a basic abstraction over client/server-side HTTP.
|
org.springframework.http.client.reactive |
Abstractions for reactive HTTP client support including
ClientHttpRequest and
ClientHttpResponse as well as a
ClientHttpConnector . |
org.springframework.http.codec.json |
JSON encoder and decoder support.
|
org.springframework.http.codec.multipart |
Multipart support.
|
org.springframework.http.codec.protobuf |
Provides an encoder and a decoder for
Google Protocol Buffers.
|
org.springframework.http.codec.xml |
XML encoder and decoder support.
|
org.springframework.http.server.reactive |
Abstractions for reactive HTTP server support including a
ServerHttpRequest and
ServerHttpResponse along with an
HttpHandler for processing. |
org.springframework.mock.http.client.reactive |
Mock implementations of reactive HTTP client contracts.
|
org.springframework.mock.http.server.reactive |
Mock implementations of reactive HTTP server contracts.
|
org.springframework.web.reactive.function |
Provides a foundation for both the reactive client and server subpackages.
|
org.springframework.web.reactive.function.client |
Provides a reactive
WebClient
that builds on top of the
org.springframework.http.client.reactive reactive HTTP adapter layer. |
org.springframework.web.reactive.function.server |
Provides the types that make up Spring's functional web framework.
|
org.springframework.web.reactive.socket |
Abstractions and support classes for reactive WebSocket interactions.
|
org.springframework.web.reactive.socket.adapter |
Classes adapting Spring's Reactive WebSocket API to and from WebSocket runtimes.
|
Modifier and Type | Method and Description |
---|---|
protected DataBuffer |
DataBufferDecoder.decodeDataBuffer(DataBuffer buffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
DataBufferDecoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
ByteArrayEncoder.encode(org.reactivestreams.Publisher<? extends byte[]> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
ByteBufferEncoder.encode(org.reactivestreams.Publisher<? extends ByteBuffer> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
CharSequenceEncoder.encode(org.reactivestreams.Publisher<? extends CharSequence> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
DataBufferEncoder.encode(org.reactivestreams.Publisher<? extends DataBuffer> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
ResourceRegionEncoder.encode(org.reactivestreams.Publisher<? extends ResourceRegion> input,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<DataBuffer> |
Encoder.encode(org.reactivestreams.Publisher<? extends T> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints)
Encode a stream of Objects of type
T into a DataBuffer
output stream. |
reactor.core.publisher.Flux<DataBuffer> |
AbstractSingleValueEncoder.encode(org.reactivestreams.Publisher<? extends T> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
protected reactor.core.publisher.Flux<DataBuffer> |
ResourceEncoder.encode(Resource resource,
DataBufferFactory bufferFactory,
ResolvableType type,
MimeType mimeType,
Map<String,Object> hints) |
protected abstract reactor.core.publisher.Flux<DataBuffer> |
AbstractSingleValueEncoder.encode(T t,
DataBufferFactory dataBufferFactory,
ResolvableType type,
MimeType mimeType,
Map<String,Object> hints)
Encode
T to an output DataBuffer stream. |
Modifier and Type | Method and Description |
---|---|
protected DataBuffer |
DataBufferDecoder.decodeDataBuffer(DataBuffer buffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
protected ByteBuffer |
ByteBufferDecoder.decodeDataBuffer(DataBuffer dataBuffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
protected String |
StringDecoder.decodeDataBuffer(DataBuffer dataBuffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
protected Resource |
ResourceDecoder.decodeDataBuffer(DataBuffer dataBuffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
protected abstract T |
AbstractDataBufferDecoder.decodeDataBuffer(DataBuffer buffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints)
How to decode a
DataBuffer to the target element type. |
protected byte[] |
ByteArrayDecoder.decodeDataBuffer(DataBuffer dataBuffer,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
DataBufferDecoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<String> |
StringDecoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<Resource> |
ResourceDecoder.decode(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<T> |
AbstractDataBufferDecoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<T> |
Decoder.decode(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints)
Decode a
DataBuffer input stream into a Flux of T . |
reactor.core.publisher.Mono<T> |
AbstractDecoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Mono<T> |
AbstractDataBufferDecoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Mono<T> |
Decoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints)
Decode a
DataBuffer input stream into a Mono of T . |
reactor.core.publisher.Flux<DataBuffer> |
DataBufferEncoder.encode(org.reactivestreams.Publisher<? extends DataBuffer> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Interface and Description |
---|---|
interface |
PooledDataBuffer
Extension of
DataBuffer that allows for buffer that share
a memory pool. |
Modifier and Type | Class and Description |
---|---|
class |
DefaultDataBuffer
Default implementation of the
DataBuffer interface that uses a
ByteBuffer internally. |
class |
NettyDataBuffer
Implementation of the
DataBuffer interface that wraps a Netty
ByteBuf . |
Modifier and Type | Method and Description |
---|---|
static <T extends DataBuffer> |
DataBufferUtils.retain(T dataBuffer)
Retain the given data buffer, it it is a
PooledDataBuffer . |
Modifier and Type | Method and Description |
---|---|
DataBuffer |
DataBufferFactory.allocateBuffer()
Allocate a data buffer of a default initial capacity.
|
DataBuffer |
DataBufferFactory.allocateBuffer(int initialCapacity)
Allocate a data buffer of the given initial capacity.
|
DataBuffer |
DataBuffer.capacity(int capacity)
Set the number of bytes that this buffer can contain.
|
default DataBuffer |
DataBuffer.ensureCapacity(int capacity)
Ensure that the current buffer has enough
writableByteCount()
to write the amount of data given as an argument. |
DataBuffer |
DefaultDataBuffer.ensureCapacity(int length) |
DataBuffer |
NettyDataBuffer.ensureCapacity(int capacity) |
DataBuffer |
DataBufferFactory.join(List<? extends DataBuffer> dataBuffers)
Return a new
DataBuffer composed of the dataBuffers elements joined together. |
DataBuffer |
NettyDataBufferFactory.join(List<? extends DataBuffer> dataBuffers)
Return a new
DataBuffer composed of the dataBuffers elements joined together. |
DataBuffer |
DataBuffer.read(byte[] destination)
Read this buffer's data into the specified destination, starting at the current
reading position of this buffer.
|
DataBuffer |
DataBuffer.read(byte[] destination,
int offset,
int length)
Read at most
length bytes of this buffer into the specified destination,
starting at the current reading position of this buffer. |
DataBuffer |
DataBuffer.readPosition(int readPosition)
Set the position from which this buffer will read.
|
DataBuffer |
DataBuffer.slice(int index,
int length)
Create a new
DataBuffer whose contents is a shared subsequence of this
data buffer's content. |
DataBuffer |
DataBufferFactory.wrap(byte[] bytes)
Wrap the given
byte array in a DataBuffer . |
DataBuffer |
NettyDataBufferFactory.wrap(byte[] bytes) |
DataBuffer |
DataBufferFactory.wrap(ByteBuffer byteBuffer)
Wrap the given
ByteBuffer in a DataBuffer . |
DataBuffer |
DataBuffer.write(byte b)
Write a single byte into this buffer at the current writing position.
|
DataBuffer |
DataBuffer.write(byte[] source)
Write the given source into this buffer, starting at the current writing position
of this buffer.
|
DataBuffer |
DataBuffer.write(byte[] source,
int offset,
int length)
Write at most
length bytes of the given source into this buffer, starting
at the current writing position of this buffer. |
DataBuffer |
DataBuffer.write(ByteBuffer... buffers)
Write one or more
ByteBuffer to this buffer, starting at the current
writing position. |
default DataBuffer |
DataBuffer.write(CharSequence charSequence,
Charset charset)
Write the given
CharSequence using the given Charset ,
starting at the current writing position. |
DataBuffer |
NettyDataBuffer.write(CharSequence charSequence,
Charset charset) |
DataBuffer |
DataBuffer.write(DataBuffer... buffers)
Write one or more
DataBuffer s to this buffer, starting at the current
writing position. |
DataBuffer |
DataBuffer.writePosition(int writePosition)
Set the position to which this buffer will write.
|
Modifier and Type | Method and Description |
---|---|
static reactor.core.publisher.Mono<DataBuffer> |
DataBufferUtils.join(org.reactivestreams.Publisher<DataBuffer> dataBuffers)
Return a new
DataBuffer composed from joining together the given
dataBuffers elements. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.read(Resource resource,
DataBufferFactory bufferFactory,
int bufferSize)
Read the given
Resource into a Flux of DataBuffer s. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.read(Resource resource,
long position,
DataBufferFactory bufferFactory,
int bufferSize)
Read the given
Resource into a Flux of DataBuffer s
starting at the given position. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.readAsynchronousFileChannel(Callable<AsynchronousFileChannel> channelSupplier,
DataBufferFactory bufferFactory,
int bufferSize)
Obtain a
AsynchronousFileChannel from the given supplier, and read
it into a Flux of DataBuffer s. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.readAsynchronousFileChannel(Callable<AsynchronousFileChannel> channelSupplier,
long position,
DataBufferFactory bufferFactory,
int bufferSize)
Obtain a
AsynchronousFileChannel from the given supplier, and
read it into a Flux of DataBuffer s, starting at the given
position. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.readByteChannel(Callable<ReadableByteChannel> channelSupplier,
DataBufferFactory bufferFactory,
int bufferSize)
|
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.readInputStream(Callable<InputStream> inputStreamSupplier,
DataBufferFactory bufferFactory,
int bufferSize)
|
static Consumer<DataBuffer> |
DataBufferUtils.releaseConsumer()
Return a consumer that calls
DataBufferUtils.release(DataBuffer) on all
passed data buffers. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.skipUntilByteCount(org.reactivestreams.Publisher<DataBuffer> publisher,
long maxByteCount)
Skip buffers from the given
Publisher until the total
byte count reaches
the given maximum byte count, or until the publisher is complete. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.takeUntilByteCount(org.reactivestreams.Publisher<DataBuffer> publisher,
long maxByteCount)
Relay buffers from the given
Publisher until the total
byte count reaches
the given maximum byte count, or until the publisher is complete. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
AsynchronousFileChannel channel)
Write the given stream of
DataBuffers to the given
AsynchronousFileChannel . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
AsynchronousFileChannel channel,
long position)
Write the given stream of
DataBuffers to the given
AsynchronousFileChannel . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
OutputStream outputStream)
Write the given stream of
DataBuffers to the given
OutputStream . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
WritableByteChannel channel)
Write the given stream of
DataBuffers to the given
WritableByteChannel . |
Modifier and Type | Method and Description |
---|---|
static boolean |
DataBufferUtils.release(DataBuffer dataBuffer)
Release the given data buffer, if it is a
PooledDataBuffer and
has been allocated. |
static io.netty.buffer.ByteBuf |
NettyDataBufferFactory.toByteBuf(DataBuffer buffer)
Return the given Netty
DataBuffer as a ByteBuf . |
DataBuffer |
DataBuffer.write(DataBuffer... buffers)
Write one or more
DataBuffer s to this buffer, starting at the current
writing position. |
DefaultDataBuffer |
DefaultDataBuffer.write(DataBuffer... buffers) |
NettyDataBuffer |
NettyDataBuffer.write(DataBuffer... buffers) |
Modifier and Type | Method and Description |
---|---|
DataBuffer |
DataBufferFactory.join(List<? extends DataBuffer> dataBuffers)
Return a new
DataBuffer composed of the dataBuffers elements joined together. |
DefaultDataBuffer |
DefaultDataBufferFactory.join(List<? extends DataBuffer> dataBuffers)
Return a new
DataBuffer composed of the dataBuffers elements joined together. |
DataBuffer |
NettyDataBufferFactory.join(List<? extends DataBuffer> dataBuffers)
Return a new
DataBuffer composed of the dataBuffers elements joined together. |
static reactor.core.publisher.Mono<DataBuffer> |
DataBufferUtils.join(org.reactivestreams.Publisher<DataBuffer> dataBuffers)
Return a new
DataBuffer composed from joining together the given
dataBuffers elements. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.skipUntilByteCount(org.reactivestreams.Publisher<DataBuffer> publisher,
long maxByteCount)
Skip buffers from the given
Publisher until the total
byte count reaches
the given maximum byte count, or until the publisher is complete. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.takeUntilByteCount(org.reactivestreams.Publisher<DataBuffer> publisher,
long maxByteCount)
Relay buffers from the given
Publisher until the total
byte count reaches
the given maximum byte count, or until the publisher is complete. |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
AsynchronousFileChannel channel)
Write the given stream of
DataBuffers to the given
AsynchronousFileChannel . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
AsynchronousFileChannel channel,
long position)
Write the given stream of
DataBuffers to the given
AsynchronousFileChannel . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
OutputStream outputStream)
Write the given stream of
DataBuffers to the given
OutputStream . |
static reactor.core.publisher.Flux<DataBuffer> |
DataBufferUtils.write(org.reactivestreams.Publisher<DataBuffer> source,
WritableByteChannel channel)
Write the given stream of
DataBuffers to the given
WritableByteChannel . |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
ReactiveHttpInputMessage.getBody()
Return the body of the message as a
Publisher . |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Mono<Void> |
ReactiveHttpOutputMessage.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body)
Use the given
Publisher of Publishers to write the body
of the HttpOutputMessage to the underlying HTTP layer, flushing after
each Publisher<DataBuffer> . |
reactor.core.publisher.Mono<Void> |
ReactiveHttpOutputMessage.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body)
Use the given
Publisher to write the body of the message to the
underlying HTTP layer. |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
ClientHttpResponseDecorator.getBody() |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Mono<Void> |
ClientHttpRequestDecorator.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
reactor.core.publisher.Mono<Void> |
ClientHttpRequestDecorator.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
AbstractJackson2Encoder.encode(org.reactivestreams.Publisher<?> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<Object> |
AbstractJackson2Decoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Mono<Object> |
AbstractJackson2Decoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
Part.content()
Return the content for this part.
|
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
ProtobufEncoder.encode(org.reactivestreams.Publisher<? extends com.google.protobuf.Message> inputStream,
DataBufferFactory bufferFactory,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<com.google.protobuf.Message> |
ProtobufDecoder.decode(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Mono<com.google.protobuf.Message> |
ProtobufDecoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
protected reactor.core.publisher.Flux<DataBuffer> |
Jaxb2XmlEncoder.encode(Object value,
DataBufferFactory bufferFactory,
ResolvableType type,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<XMLEvent> |
XmlEventDecoder.decode(org.reactivestreams.Publisher<DataBuffer> input,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Flux<Object> |
Jaxb2XmlDecoder.decode(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
reactor.core.publisher.Mono<Object> |
Jaxb2XmlDecoder.decodeToMono(org.reactivestreams.Publisher<DataBuffer> inputStream,
ResolvableType elementType,
MimeType mimeType,
Map<String,Object> hints) |
Modifier and Type | Method and Description |
---|---|
protected abstract org.reactivestreams.Processor<? super org.reactivestreams.Publisher<? extends DataBuffer>,Void> |
AbstractListenerServerHttpResponse.createBodyFlushProcessor()
Abstract template method to create a
Processor<Publisher<DataBuffer>, Void>
that will write the response body with flushes to the underlying output. |
reactor.core.publisher.Flux<DataBuffer> |
ServerHttpRequestDecorator.getBody() |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Mono<Void> |
HttpHeadResponseDecorator.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body)
Invoke
ServerHttpResponseDecorator.setComplete() without writing. |
reactor.core.publisher.Mono<Void> |
ServerHttpResponseDecorator.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
reactor.core.publisher.Mono<Void> |
AbstractServerHttpResponse.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
protected reactor.core.publisher.Mono<Void> |
AbstractListenerServerHttpResponse.writeAndFlushWithInternal(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
protected abstract reactor.core.publisher.Mono<Void> |
AbstractServerHttpResponse.writeAndFlushWithInternal(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body)
Write to the underlying the response, and flush after each
Publisher<DataBuffer> . |
reactor.core.publisher.Mono<Void> |
HttpHeadResponseDecorator.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body)
Apply
reduce on the body, count
the number of bytes produced, release data buffers without writing, and
set the Content-Length header. |
reactor.core.publisher.Mono<Void> |
ServerHttpResponseDecorator.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body) |
reactor.core.publisher.Mono<Void> |
AbstractServerHttpResponse.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body) |
protected reactor.core.publisher.Mono<Void> |
AbstractListenerServerHttpResponse.writeWithInternal(org.reactivestreams.Publisher<? extends DataBuffer> body) |
protected abstract reactor.core.publisher.Mono<Void> |
AbstractServerHttpResponse.writeWithInternal(org.reactivestreams.Publisher<? extends DataBuffer> body)
Write to the underlying the response.
|
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
MockClientHttpRequest.getBody()
Return the request body, or an error stream if the body was never set
or when
MockClientHttpRequest.setWriteHandler(java.util.function.Function<reactor.core.publisher.Flux<org.springframework.core.io.buffer.DataBuffer>, reactor.core.publisher.Mono<java.lang.Void>>) is configured. |
reactor.core.publisher.Flux<DataBuffer> |
MockClientHttpResponse.getBody() |
Modifier and Type | Method and Description |
---|---|
void |
MockClientHttpResponse.setBody(org.reactivestreams.Publisher<DataBuffer> body) |
void |
MockClientHttpRequest.setWriteHandler(Function<reactor.core.publisher.Flux<DataBuffer>,reactor.core.publisher.Mono<Void>> writeHandler)
Configure a custom handler for writing the request body.
|
reactor.core.publisher.Mono<Void> |
MockClientHttpRequest.writeAndFlushWith(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
reactor.core.publisher.Mono<Void> |
MockClientHttpRequest.writeWith(org.reactivestreams.Publisher<? extends DataBuffer> body) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<DataBuffer> |
MockServerHttpResponse.getBody()
Return the response body or an error stream if the body was not set.
|
reactor.core.publisher.Flux<DataBuffer> |
MockServerHttpRequest.getBody() |
Modifier and Type | Method and Description |
---|---|
MockServerHttpRequest |
MockServerHttpRequest.BodyBuilder.body(org.reactivestreams.Publisher<? extends DataBuffer> body)
Set the body of the request and build it.
|
void |
MockServerHttpResponse.setWriteHandler(Function<reactor.core.publisher.Flux<DataBuffer>,reactor.core.publisher.Mono<Void>> writeHandler)
Configure a custom handler to consume the response body.
|
protected reactor.core.publisher.Mono<Void> |
MockServerHttpResponse.writeAndFlushWithInternal(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends DataBuffer>> body) |
protected reactor.core.publisher.Mono<Void> |
MockServerHttpResponse.writeWithInternal(org.reactivestreams.Publisher<? extends DataBuffer> body) |
Modifier and Type | Method and Description |
---|---|
static <T extends org.reactivestreams.Publisher<DataBuffer>> |
BodyInserters.fromDataBuffers(T publisher)
Inserter to write the given
Publisher<DataBuffer> to the body. |
Modifier and Type | Method and Description |
---|---|
static BodyExtractor<reactor.core.publisher.Flux<DataBuffer>,ReactiveHttpInputMessage> |
BodyExtractors.toDataBuffers()
Extractor that returns the raw
DataBuffers . |
Modifier and Type | Method and Description |
---|---|
ClientResponse.Builder |
ClientResponse.Builder.body(reactor.core.publisher.Flux<DataBuffer> body)
Set the body of the response.
|
Modifier and Type | Method and Description |
---|---|
ServerRequest.Builder |
ServerRequest.Builder.body(reactor.core.publisher.Flux<DataBuffer> body)
Set the body of the request.
|
Modifier and Type | Method and Description |
---|---|
DataBuffer |
WebSocketMessage.getPayload()
Return the message payload.
|
Modifier and Type | Method and Description |
---|---|
WebSocketMessage |
WebSocketSession.binaryMessage(Function<DataBufferFactory,DataBuffer> payloadFactory)
Factory method to create a binary WebSocketMessage using the
WebSocketSession.bufferFactory() for the session. |
WebSocketMessage |
WebSocketSession.pingMessage(Function<DataBufferFactory,DataBuffer> payloadFactory)
Factory method to create a ping WebSocketMessage using the
WebSocketSession.bufferFactory() for the session. |
WebSocketMessage |
WebSocketSession.pongMessage(Function<DataBufferFactory,DataBuffer> payloadFactory)
Factory method to create a pong WebSocketMessage using the
WebSocketSession.bufferFactory() for the session. |
Constructor and Description |
---|
WebSocketMessage(WebSocketMessage.Type type,
DataBuffer payload)
Constructor for a WebSocketMessage.
|
Modifier and Type | Method and Description |
---|---|
WebSocketMessage |
AbstractWebSocketSession.binaryMessage(Function<DataBufferFactory,DataBuffer> payloadFactory) |
WebSocketMessage |
AbstractWebSocketSession.pingMessage(Function<DataBufferFactory,DataBuffer> payloadFactory) |
WebSocketMessage |
AbstractWebSocketSession.pongMessage(Function<DataBufferFactory,DataBuffer> payloadFactory) |