Uses of Interface
org.springframework.core.io.buffer.DataBuffer
Package
Description
Generic abstraction for working with byte buffer implementations.
Contains a basic abstraction over client/server-side HTTP.
Abstractions for reactive HTTP client support including
ClientHttpRequest
and
ClientHttpResponse
as well as a
ClientHttpConnector
.CBOR encoder and decoder support.
JSON encoder and decoder support.
Multipart support.
Provides an encoder and a decoder for
Google Protocol Buffers.
XML encoder and decoder support.
Abstractions for reactive HTTP server support including a
ServerHttpRequest
and
ServerHttpResponse
along with an
HttpHandler
for processing.Common infrastructure for invoking message handler methods with non-blocking,
and reactive contracts.
Support for the RSocket protocol.
Support classes for working with annotated RSocket stream handling methods.
Mock implementations of reactive HTTP client contracts.
Mock implementations of reactive HTTP server contracts.
Provides a foundation for both the reactive client and server subpackages.
Provides a reactive
WebClient
that builds on top of the
org.springframework.http.client.reactive
reactive HTTP adapter layer.Provides the types that make up Spring's functional web framework for Reactive environments.
Abstractions and support classes for reactive WebSocket interactions.
Classes adapting Spring's Reactive WebSocket API to and from WebSocket runtimes.
-
Uses of DataBuffer in org.springframework.core.codec
Modifier and TypeMethodDescriptionDataBufferDecoder.decode
(DataBuffer buffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) ByteArrayEncoder.encodeValue
(byte[] bytes, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) ByteBufferEncoder.encodeValue
(ByteBuffer byteBuffer, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) CharSequenceEncoder.encodeValue
(CharSequence charSequence, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) DataBufferEncoder.encodeValue
(DataBuffer buffer, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) default DataBuffer
Encoder.encodeValue
(T value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Encode an Object of type T to a data buffer.Netty5BufferEncoder.encodeValue
(io.netty5.buffer.Buffer buffer, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) NettyByteBufEncoder.encodeValue
(io.netty.buffer.ByteBuf byteBuf, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
DataBufferDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) final reactor.core.publisher.Flux<DataBuffer>
AbstractSingleValueEncoder.encode
(Publisher<? extends T> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, 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) EncodeT
to an outputDataBuffer
stream.reactor.core.publisher.Flux<DataBuffer>
ByteArrayEncoder.encode
(Publisher<? extends byte[]> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
ByteBufferEncoder.encode
(Publisher<? extends ByteBuffer> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
CharSequenceEncoder.encode
(Publisher<? extends CharSequence> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
DataBufferEncoder.encode
(Publisher<? extends DataBuffer> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
Encoder.encode
(Publisher<? extends T> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Encode a stream of Objects of typeT
into aDataBuffer
output stream.reactor.core.publisher.Flux<DataBuffer>
Netty5BufferEncoder.encode
(Publisher<? extends io.netty5.buffer.Buffer> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
NettyByteBufEncoder.encode
(Publisher<? extends io.netty.buffer.ByteBuf> 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) reactor.core.publisher.Flux<DataBuffer>
ResourceRegionEncoder.encode
(Publisher<? extends ResourceRegion> input, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionfinal T
AbstractCharSequenceDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) byte[]
ByteArrayDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) ByteBufferDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) DataBufferDecoder.decode
(DataBuffer buffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) default T
Decoder.decode
(DataBuffer buffer, ResolvableType targetType, MimeType mimeType, Map<String, Object> hints) Decode a data buffer to an Object of type T.io.netty5.buffer.Buffer
Netty5BufferDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) io.netty.buffer.ByteBuf
NettyByteBufDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) ResourceDecoder.decode
(DataBuffer dataBuffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) protected T
AbstractDataBufferDecoder.decodeDataBuffer
(DataBuffer buffer, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Deprecated.protected abstract T
AbstractCharSequenceDecoder.decodeInternal
(DataBuffer dataBuffer, Charset charset) Template method that decodes the given data buffer intoT
, given the charset.protected CharBuffer
CharBufferDecoder.decodeInternal
(DataBuffer dataBuffer, Charset charset) protected String
StringDecoder.decodeInternal
(DataBuffer dataBuffer, Charset charset) DataBufferEncoder.encodeValue
(DataBuffer buffer, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) static void
Hints.touchDataBuffer
(DataBuffer buffer, Map<String, Object> hints, Log logger) If the hints contain aHints.LOG_PREFIX_HINT
and the given logger has DEBUG level enabled, apply the log prefix as a hint to the given buffer viaDataBufferUtils.touch(DataBuffer, Object)
.Modifier and TypeMethodDescriptionfinal reactor.core.publisher.Flux<T>
AbstractCharSequenceDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<T>
AbstractDataBufferDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
DataBufferDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<T>
Decoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Decode aDataBuffer
input stream into a Flux ofT
.reactor.core.publisher.Flux<Resource>
ResourceDecoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<T>
AbstractDataBufferDecoder.decodeToMono
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<T>
AbstractDecoder.decodeToMono
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<T>
Decoder.decodeToMono
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Decode aDataBuffer
input stream into a Mono ofT
.reactor.core.publisher.Flux<DataBuffer>
DataBufferEncoder.encode
(Publisher<? extends DataBuffer> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.core.io.buffer
Modifier and TypeInterfaceDescriptioninterface
Extension ofDataBuffer
that allows for buffers that can be used in atry
-with-resources statement.interface
Extension ofDataBuffer
that allows for buffers that share a memory pool.interface
Extension ofDataBuffer
that allows for buffers that can be given hints for debugging purposes.Modifier and TypeClassDescriptionclass
Provides a convenient implementation of theDataBuffer
interface that can be overridden to adapt the delegate.class
Default implementation of theDataBuffer
interface that uses aByteBuffer
internally.final class
Implementation of theDataBuffer
interface that wraps a Netty 5Buffer
.class
Implementation of theDataBuffer
interface that wraps a Netty 4ByteBuf
.Modifier and TypeMethodDescriptionstatic <T extends DataBuffer>
TDataBufferUtils.retain
(T dataBuffer) Retain the given data buffer, if it is aPooledDataBuffer
.static <T extends DataBuffer>
reactor.core.publisher.Flux<T>DataBufferUtils.skipUntilByteCount
(Publisher<T> publisher, long maxByteCount) Skip buffers from the givenPublisher
until the total byte count reaches the given maximum byte count, or until the publisher is complete.static <T extends DataBuffer>
reactor.core.publisher.Flux<T>DataBufferUtils.takeUntilByteCount
(Publisher<T> publisher, long maxByteCount) Relay buffers from the givenPublisher
until the total byte count reaches the given maximum byte count, or until the publisher is complete.static <T extends DataBuffer>
TAssociate the given hint with the data buffer if it is a pooled buffer and supports leak tracking.Modifier and TypeMethodDescriptionDataBufferFactory.allocateBuffer()
Deprecated.as of 6.0, in favor ofDataBufferFactory.allocateBuffer(int)
DataBufferFactory.allocateBuffer
(int initialCapacity) Allocate a data buffer of the given initial capacity.DataBuffer.capacity
(int capacity) Deprecated.as of 6.0, in favor ofensureWritable(int)
, which has different semanticsDataBufferWrapper.capacity
(int capacity) Deprecated.DefaultDataBuffer.capacity
(int capacity) Deprecated.DataBufferWrapper.dataBuffer()
Return the wrapped delegate.default DataBuffer
DataBuffer.ensureCapacity
(int capacity) Deprecated.since 6.0, in favor ofensureWritable(int)
DataBufferWrapper.ensureCapacity
(int capacity) Deprecated.DataBuffer.ensureWritable
(int capacity) Ensure that the current buffer has enoughwritableByteCount()
to write the amount of data given as an argument.DataBufferWrapper.ensureWritable
(int capacity) DefaultDataBuffer.ensureWritable
(int length) Netty5DataBuffer.ensureWritable
(int capacity) NettyDataBuffer.ensureWritable
(int capacity) DataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.Netty5DataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.NettyDataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.DataBuffer.read
(byte[] destination) Read this buffer's data into the specified destination, starting at the current reading position of this buffer.DataBuffer.read
(byte[] destination, int offset, int length) Read at mostlength
bytes of this buffer into the specified destination, starting at the current reading position of this buffer.DataBufferWrapper.read
(byte[] destination) DataBufferWrapper.read
(byte[] destination, int offset, int length) DataBuffer.readPosition
(int readPosition) Set the position from which this buffer will read.DataBufferWrapper.readPosition
(int readPosition) LimitedDataBufferList.remove
(int index) default DataBuffer
DataBuffer.retainedSlice
(int index, int length) Deprecated.as of 6.0, in favor ofsplit(int)
, which has different semanticsDataBufferWrapper.retainedSlice
(int index, int length) Deprecated.LimitedDataBufferList.set
(int index, DataBuffer element) DataBuffer.slice
(int index, int length) Deprecated.as of 6.0, in favor ofsplit(int)
, which has different semanticsDataBufferWrapper.slice
(int index, int length) Deprecated.Netty5DataBuffer.slice
(int index, int length) Deprecated.DataBuffer.split
(int index) Splits this data buffer into two at the given index.DataBufferWrapper.split
(int index) DefaultDataBuffer.split
(int index) Netty5DataBuffer.split
(int index) DataBufferFactory.wrap
(byte[] bytes) Wrap the givenbyte
array in aDataBuffer
.DataBufferFactory.wrap
(ByteBuffer byteBuffer) Wrap the givenByteBuffer
in aDataBuffer
.NettyDataBufferFactory.wrap
(byte[] bytes) DataBuffer.write
(byte b) Write a single byte into this buffer at the current writing position.DataBuffer.write
(byte[] source) Write the given source into this buffer, starting at the current writing position of this buffer.DataBuffer.write
(byte[] source, int offset, int length) Write at mostlength
bytes of the given source into this buffer, starting at the current writing position of this buffer.default DataBuffer
DataBuffer.write
(CharSequence charSequence, Charset charset) Write the givenCharSequence
using the givenCharset
, starting at the current writing position.DataBuffer.write
(ByteBuffer... buffers) Write one or moreByteBuffer
to this buffer, starting at the current writing position.DataBuffer.write
(DataBuffer... buffers) Write one or moreDataBuffer
s to this buffer, starting at the current writing position.DataBufferWrapper.write
(byte b) DataBufferWrapper.write
(byte[] source) DataBufferWrapper.write
(byte[] source, int offset, int length) DataBufferWrapper.write
(CharSequence charSequence, Charset charset) DataBufferWrapper.write
(ByteBuffer... buffers) DataBufferWrapper.write
(DataBuffer... buffers) Netty5DataBuffer.write
(CharSequence charSequence, Charset charset) NettyDataBuffer.write
(CharSequence charSequence, Charset charset) DataBuffer.writePosition
(int writePosition) Set the position to which this buffer will write.DataBufferWrapper.writePosition
(int writePosition) Modifier and TypeMethodDescriptionstatic reactor.core.publisher.Mono<DataBuffer>
DataBufferUtils.join
(Publisher<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of joining together the givendataBuffers
elements.static reactor.core.publisher.Mono<DataBuffer>
DataBufferUtils.join
(Publisher<? extends DataBuffer> buffers, int maxByteCount) Variant ofDataBufferUtils.join(Publisher)
that behaves the same way up until the specified max number of bytes to buffer.static Publisher<DataBuffer>
DataBufferUtils.outputStreamPublisher
(Consumer<OutputStream> outputStreamConsumer, DataBufferFactory bufferFactory, Executor executor) Create a newPublisher<DataBuffer>
based on bytes written to aOutputStream
.static Publisher<DataBuffer>
DataBufferUtils.outputStreamPublisher
(Consumer<OutputStream> outputStreamConsumer, DataBufferFactory bufferFactory, Executor executor, int chunkSize) Creates a newPublisher<DataBuffer>
based on bytes written to aOutputStream
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.read
(Path path, DataBufferFactory bufferFactory, int bufferSize, OpenOption... options) Read bytes from the given filePath
into aFlux
ofDataBuffer
s.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.read
(Resource resource, long position, DataBufferFactory bufferFactory, int bufferSize) Read the givenResource
into aFlux
ofDataBuffer
s starting at the given position.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.read
(Resource resource, DataBufferFactory bufferFactory, int bufferSize) Read the givenResource
into aFlux
ofDataBuffer
s.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.readAsynchronousFileChannel
(Callable<AsynchronousFileChannel> channelSupplier, long position, DataBufferFactory bufferFactory, int bufferSize) Obtain anAsynchronousFileChannel
from the given supplier, and read it into aFlux
ofDataBuffer
s, starting at the given position.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.readAsynchronousFileChannel
(Callable<AsynchronousFileChannel> channelSupplier, DataBufferFactory bufferFactory, int bufferSize) Obtain aAsynchronousFileChannel
from the given supplier, and read it into aFlux
ofDataBuffer
s.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 callsDataBufferUtils.release(DataBuffer)
on all passed data buffers.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<? extends DataBuffer> source, AsynchronousFileChannel channel, long position) Write the given stream ofDataBuffers
to the givenAsynchronousFileChannel
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, OutputStream outputStream) Write the given stream ofDataBuffers
to the givenOutputStream
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, AsynchronousFileChannel channel) Write the given stream ofDataBuffers
to the givenAsynchronousFileChannel
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, WritableByteChannel channel) Write the given stream ofDataBuffers
to the givenWritableByteChannel
.Modifier and TypeMethodDescriptionvoid
LimitedDataBufferList.add
(int index, DataBuffer buffer) boolean
LimitedDataBufferList.add
(DataBuffer buffer) int
DataBufferUtils.Matcher.match
(DataBuffer dataBuffer) Find the first matching delimiter and return the index of the last byte of the delimiter, or-1
if not found.static boolean
DataBufferUtils.release
(DataBuffer dataBuffer) Release the given data buffer.LimitedDataBufferList.set
(int index, DataBuffer element) static io.netty5.buffer.Buffer
Netty5DataBufferFactory.toBuffer
(DataBuffer buffer) Return the given NettyDataBuffer
as aBuffer
.static io.netty.buffer.ByteBuf
NettyDataBufferFactory.toByteBuf
(DataBuffer dataBuffer) Return the given NettyDataBuffer
as aByteBuf
.DataBuffer.write
(DataBuffer... buffers) Write one or moreDataBuffer
s to this buffer, starting at the current writing position.DataBufferWrapper.write
(DataBuffer... buffers) DefaultDataBuffer.write
(DataBuffer... dataBuffers) Netty5DataBuffer.write
(DataBuffer... dataBuffers) NettyDataBuffer.write
(DataBuffer... dataBuffers) Modifier and TypeMethodDescriptionboolean
LimitedDataBufferList.addAll
(int index, Collection<? extends DataBuffer> collection) boolean
LimitedDataBufferList.addAll
(Collection<? extends DataBuffer> collection) DataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.static reactor.core.publisher.Mono<DataBuffer>
DataBufferUtils.join
(Publisher<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of joining together the givendataBuffers
elements.static reactor.core.publisher.Mono<DataBuffer>
DataBufferUtils.join
(Publisher<? extends DataBuffer> buffers, int maxByteCount) Variant ofDataBufferUtils.join(Publisher)
that behaves the same way up until the specified max number of bytes to buffer.DefaultDataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.Netty5DataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.NettyDataBufferFactory.join
(List<? extends DataBuffer> dataBuffers) Return a newDataBuffer
composed of thedataBuffers
elements joined together.boolean
LimitedDataBufferList.removeIf
(Predicate<? super DataBuffer> filter) static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<? extends DataBuffer> source, AsynchronousFileChannel channel, long position) Write the given stream ofDataBuffers
to the givenAsynchronousFileChannel
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, OutputStream outputStream) Write the given stream ofDataBuffers
to the givenOutputStream
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, AsynchronousFileChannel channel) Write the given stream ofDataBuffers
to the givenAsynchronousFileChannel
.static reactor.core.publisher.Flux<DataBuffer>
DataBufferUtils.write
(Publisher<DataBuffer> source, WritableByteChannel channel) Write the given stream ofDataBuffers
to the givenWritableByteChannel
.static reactor.core.publisher.Mono<Void>
DataBufferUtils.write
(Publisher<DataBuffer> source, Path destination, OpenOption... options) Write the given stream ofDataBuffers
to the given filePath
.ModifierConstructorDescriptionDataBufferWrapper
(DataBuffer delegate) Create a newDataBufferWrapper
that wraps the given buffer. -
Uses of DataBuffer in org.springframework.http
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
ReactiveHttpInputMessage.getBody()
Return the body of the message as aPublisher
.Modifier and TypeMethodDescriptionreactor.core.publisher.Mono<Void>
ReactiveHttpOutputMessage.writeAndFlushWith
(Publisher<? extends Publisher<? extends DataBuffer>> body) Use the givenPublisher
ofPublishers
to write the body of the HttpOutputMessage to the underlying HTTP layer, flushing after eachPublisher<DataBuffer>
.reactor.core.publisher.Mono<Void>
ReactiveHttpOutputMessage.writeWith
(Publisher<? extends DataBuffer> body) Use the givenPublisher
to write the body of the message to the underlying HTTP layer. -
Uses of DataBuffer in org.springframework.http.client.reactive
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
AbstractClientHttpResponse.getBody()
reactor.core.publisher.Flux<DataBuffer>
ClientHttpResponseDecorator.getBody()
Modifier and TypeMethodDescriptionreactor.core.publisher.Mono<Void>
ClientHttpRequestDecorator.writeAndFlushWith
(Publisher<? extends Publisher<? extends DataBuffer>> body) reactor.core.publisher.Mono<Void>
ClientHttpRequestDecorator.writeWith
(Publisher<? extends DataBuffer> body) ModifierConstructorDescriptionprotected
AbstractClientHttpResponse
(HttpStatusCode statusCode, HttpHeaders headers, MultiValueMap<String, ResponseCookie> cookies, reactor.core.publisher.Flux<DataBuffer> body) -
Uses of DataBuffer in org.springframework.http.codec
Modifier and TypeMethodDescriptionKotlinSerializationBinaryEncoder.encodeValue
(Object value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) KotlinSerializationStringEncoder.encodeValue
(Object value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
KotlinSerializationBinaryEncoder.encode
(Publisher<?> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<DataBuffer>
KotlinSerializationStringEncoder.encode
(Publisher<?> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<Object>
KotlinSerializationBinaryDecoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<Object>
KotlinSerializationStringDecoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<Object>
KotlinSerializationBinaryDecoder.decodeToMono
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<Object>
KotlinSerializationStringDecoder.decodeToMono
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.http.codec.cbor
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
Jackson2CborEncoder.encode
(Publisher<?> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<Object>
Jackson2CborDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.http.codec.json
Modifier and TypeMethodDescriptionAbstractJackson2Encoder.encodeValue
(Object value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
AbstractJackson2Encoder.encode
(Publisher<?> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) protected reactor.core.publisher.Flux<DataBuffer>
AbstractJackson2Decoder.processInput
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Process the input publisher into a flux.protected reactor.core.publisher.Flux<DataBuffer>
Jackson2JsonDecoder.processInput
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionAbstractJackson2Decoder.decode
(DataBuffer dataBuffer, ResolvableType targetType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<Object>
AbstractJackson2Decoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<Object>
AbstractJackson2Decoder.decodeToMono
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) protected reactor.core.publisher.Flux<DataBuffer>
AbstractJackson2Decoder.processInput
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Process the input publisher into a flux.protected reactor.core.publisher.Flux<DataBuffer>
Jackson2JsonDecoder.processInput
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.http.codec.multipart
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
Part.content()
Return the content for this part.protected reactor.core.publisher.Mono<DataBuffer>
MultipartWriterSupport.generateBoundaryLine
(byte[] boundary, DataBufferFactory bufferFactory) protected reactor.core.publisher.Mono<DataBuffer>
MultipartWriterSupport.generateLastLine
(byte[] boundary, DataBufferFactory bufferFactory) protected reactor.core.publisher.Mono<DataBuffer>
MultipartWriterSupport.generateNewLine
(DataBufferFactory bufferFactory) protected reactor.core.publisher.Mono<DataBuffer>
MultipartWriterSupport.generatePartHeaders
(HttpHeaders headers, DataBufferFactory bufferFactory) Modifier and TypeMethodDescriptionstatic reactor.core.publisher.Flux<FilePartEvent>
FilePartEvent.create
(String partName, String filename, MediaType contentType, reactor.core.publisher.Flux<DataBuffer> contents) Creates a stream ofFilePartEvent
objects based on the given name, FilePartEvent.filename(), content-type, and contents.static reactor.core.publisher.Flux<FilePartEvent>
FilePartEvent.create
(String partName, String filename, MediaType contentType, reactor.core.publisher.Flux<DataBuffer> contents, Consumer<HttpHeaders> headersConsumer) Creates a stream ofFilePartEvent
objects based on the given name, FilePartEvent.filename(), content-type, and contents. -
Uses of DataBuffer in org.springframework.http.codec.protobuf
Modifier and TypeMethodDescriptionProtobufEncoder.encodeValue
(com.google.protobuf.Message message, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
ProtobufEncoder.encode
(Publisher<? extends com.google.protobuf.Message> inputStream, DataBufferFactory bufferFactory, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptioncom.google.protobuf.Message
ProtobufDecoder.decode
(DataBuffer dataBuffer, ResolvableType targetType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<com.google.protobuf.Message>
ProtobufDecoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<com.google.protobuf.Message>
ProtobufDecoder.decodeToMono
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.http.codec.xml
Modifier and TypeMethodDescriptionJaxb2XmlEncoder.encodeValue
(Object value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionprotected reactor.core.publisher.Flux<DataBuffer>
Jaxb2XmlEncoder.encode
(Object value, DataBufferFactory bufferFactory, ResolvableType valueType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionJaxb2XmlDecoder.decode
(DataBuffer dataBuffer, ResolvableType targetType, MimeType mimeType, Map<String, Object> hints) Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<Object>
Jaxb2XmlDecoder.decode
(Publisher<DataBuffer> inputStream, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Flux<XMLEvent>
XmlEventDecoder.decode
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) reactor.core.publisher.Mono<Object>
Jaxb2XmlDecoder.decodeToMono
(Publisher<DataBuffer> input, ResolvableType elementType, MimeType mimeType, Map<String, Object> hints) -
Uses of DataBuffer in org.springframework.http.server.reactive
Modifier and TypeMethodDescriptionprotected abstract Processor<? super Publisher<? extends DataBuffer>,
Void> AbstractListenerServerHttpResponse.createBodyFlushProcessor()
Abstract template method to create aProcessor<Publisher<DataBuffer>, Void>
that will write the response body with flushes to the underlying output.reactor.core.publisher.Flux<DataBuffer>
ServerHttpRequestDecorator.getBody()
Modifier and TypeMethodDescriptionprotected void
AbstractServerHttpResponse.touchDataBuffer
(DataBuffer buffer) Allow subclasses to associate a hint with the data buffer if it is a pooled buffer and supports leak tracking.Modifier and TypeMethodDescriptionfinal reactor.core.publisher.Mono<Void>
AbstractServerHttpResponse.writeAndFlushWith
(Publisher<? extends Publisher<? extends DataBuffer>> body) final reactor.core.publisher.Mono<Void>
HttpHeadResponseDecorator.writeAndFlushWith
(Publisher<? extends Publisher<? extends DataBuffer>> body) InvokeServerHttpResponseDecorator.setComplete()
without writing.reactor.core.publisher.Mono<Void>
ServerHttpResponseDecorator.writeAndFlushWith
(Publisher<? extends Publisher<? extends DataBuffer>> body) protected final reactor.core.publisher.Mono<Void>
AbstractListenerServerHttpResponse.writeAndFlushWithInternal
(Publisher<? extends Publisher<? extends DataBuffer>> body) protected abstract reactor.core.publisher.Mono<Void>
AbstractServerHttpResponse.writeAndFlushWithInternal
(Publisher<? extends Publisher<? extends DataBuffer>> body) Write to the underlying the response, and flush after eachPublisher<DataBuffer>
.final reactor.core.publisher.Mono<Void>
AbstractServerHttpResponse.writeWith
(Publisher<? extends DataBuffer> body) final reactor.core.publisher.Mono<Void>
HttpHeadResponseDecorator.writeWith
(Publisher<? extends DataBuffer> body) Consume and release the body without writing.reactor.core.publisher.Mono<Void>
ServerHttpResponseDecorator.writeWith
(Publisher<? extends DataBuffer> body) protected final reactor.core.publisher.Mono<Void>
AbstractListenerServerHttpResponse.writeWithInternal
(Publisher<? extends DataBuffer> body) protected abstract reactor.core.publisher.Mono<Void>
AbstractServerHttpResponse.writeWithInternal
(Publisher<? extends DataBuffer> body) Write to the underlying the response. -
Uses of DataBuffer in org.springframework.messaging.handler.invocation.reactive
Modifier and TypeMethodDescriptionprotected abstract reactor.core.publisher.Mono<Void>
AbstractEncoderMethodReturnValueHandler.handleEncodedContent
(reactor.core.publisher.Flux<DataBuffer> encodedContent, MethodParameter returnType, Message<?> message) Subclasses implement this method to handle encoded values in some way such as creating and sending messages. -
Uses of DataBuffer in org.springframework.messaging.rsocket
Modifier and TypeMethodDescriptionstatic DataBuffer
PayloadUtils.retainDataAndReleasePayload
(io.rsocket.Payload payload, DataBufferFactory bufferFactory) Use this method to slice, retain and wrap the data portion of thePayload
, and also to release thePayload
.Modifier and TypeMethodDescriptionstatic io.rsocket.Payload
PayloadUtils.createPayload
(DataBuffer data) Create a Payload with data only.static io.rsocket.Payload
PayloadUtils.createPayload
(DataBuffer data, DataBuffer metadata) Create a Payload from the given metadata and data. -
Uses of DataBuffer in org.springframework.messaging.rsocket.annotation.support
Modifier and TypeMethodDescriptionprotected reactor.core.publisher.Mono<Void>
RSocketPayloadReturnValueHandler.handleEncodedContent
(reactor.core.publisher.Flux<DataBuffer> encodedContent, MethodParameter returnType, Message<?> message) -
Uses of DataBuffer in org.springframework.mock.http.client.reactive
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
MockClientHttpRequest.getBody()
Return the request body, or an error stream if the body was never set or whenMockClientHttpRequest.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 TypeMethodDescriptionvoid
MockClientHttpResponse.setBody
(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
(Publisher<? extends Publisher<? extends DataBuffer>> body) reactor.core.publisher.Mono<Void>
MockClientHttpRequest.writeWith
(Publisher<? extends DataBuffer> body) -
Uses of DataBuffer in org.springframework.mock.http.server.reactive
Modifier and TypeMethodDescriptionreactor.core.publisher.Flux<DataBuffer>
MockServerHttpRequest.getBody()
reactor.core.publisher.Flux<DataBuffer>
MockServerHttpResponse.getBody()
Return the response body or an error stream if the body was not set.Modifier and TypeMethodDescriptionMockServerHttpRequest.BodyBuilder.body
(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
(Publisher<? extends Publisher<? extends DataBuffer>> body) protected reactor.core.publisher.Mono<Void>
MockServerHttpResponse.writeWithInternal
(Publisher<? extends DataBuffer> body) -
Uses of DataBuffer in org.springframework.web.reactive.function
Modifier and TypeMethodDescriptionstatic <T extends Publisher<DataBuffer>>
BodyInserter<T,ReactiveHttpOutputMessage> BodyInserters.fromDataBuffers
(T publisher) Inserter to write the givenPublisher<DataBuffer>
to the body.static <T extends Publisher<DataBuffer>>
BodyInserter<T,ReactiveHttpOutputMessage> BodyInserters.fromOutputStream
(Consumer<OutputStream> outputStreamConsumer, Executor executor) Inserter based on bytes written to aOutputStream
.static <T extends Publisher<DataBuffer>>
BodyInserter<T,ReactiveHttpOutputMessage> BodyInserters.fromOutputStream
(Consumer<OutputStream> outputStreamConsumer, Executor executor, int chunkSize) Inserter based on bytes written to aOutputStream
.Modifier and TypeMethodDescriptionstatic BodyExtractor<reactor.core.publisher.Flux<DataBuffer>,
ReactiveHttpInputMessage> BodyExtractors.toDataBuffers()
Extractor that returns the rawDataBuffers
. -
Uses of DataBuffer in org.springframework.web.reactive.function.client
Modifier and TypeMethodDescriptionClientResponse.Builder.body
(Function<reactor.core.publisher.Flux<DataBuffer>, reactor.core.publisher.Flux<DataBuffer>> transformer) Transform the response body, if set in the builder.ClientResponse.Builder.body
(Function<reactor.core.publisher.Flux<DataBuffer>, reactor.core.publisher.Flux<DataBuffer>> transformer) Transform the response body, if set in the builder.ClientResponse.Builder.body
(reactor.core.publisher.Flux<DataBuffer> body) Set the body of the response. -
Uses of DataBuffer in org.springframework.web.reactive.function.server
Modifier and TypeMethodDescriptionServerRequest.Builder.body
(reactor.core.publisher.Flux<DataBuffer> body) Set the body of the request. -
Uses of DataBuffer in org.springframework.web.reactive.socket
Modifier and TypeMethodDescriptionWebSocketSession.binaryMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory) Factory method to create a binary WebSocketMessage using theWebSocketSession.bufferFactory()
for the session.WebSocketSession.pingMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory) Factory method to create a ping WebSocketMessage using theWebSocketSession.bufferFactory()
for the session.WebSocketSession.pongMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory) Factory method to create a pong WebSocketMessage using theWebSocketSession.bufferFactory()
for the session.ModifierConstructorDescriptionWebSocketMessage
(WebSocketMessage.Type type, DataBuffer payload) Constructor for a WebSocketMessage.WebSocketMessage
(WebSocketMessage.Type type, DataBuffer payload, Object nativeMessage) Constructor for an inbound message with access to the underlying message. -
Uses of DataBuffer in org.springframework.web.reactive.socket.adapter
Modifier and TypeMethodDescriptionAbstractWebSocketSession.binaryMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory) AbstractWebSocketSession.pingMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory) AbstractWebSocketSession.pongMessage
(Function<DataBufferFactory, DataBuffer> payloadFactory)
Decoder.decode(DataBuffer, ResolvableType, MimeType, Map)
instead