Skip navigation links
A B C D E F G H I K L M N O P Q R S T U V W Z 

A

AbstractRSocket - Class in io.rsocket
An abstract implementation of RSocket.
AbstractRSocket() - Constructor for class io.rsocket.AbstractRSocket
 
accept(T) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue.Consumer
 
accept(ConnectionSetupPayload, RSocket) - Method in interface io.rsocket.SocketAcceptor
Accepts a new RSocket used to send requests to the peer and returns another RSocket that is used for accepting requests from the peer.
accept(T) - Method in class io.rsocket.util.OnceConsumer
 
acceptOnce(T) - Method in class io.rsocket.util.OnceConsumer
 
acceptor(Function<RSocket, RSocket>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
acceptor(Supplier<Function<RSocket, RSocket>>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
acceptor(BiFunction<ConnectionSetupPayload, RSocket, RSocket>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
acceptor(SocketAcceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
acceptRSocketResume(ByteBuf, ClientServerInputMultiplexer) - Method in interface io.rsocket.internal.ServerSetup
 
acceptRSocketResume(ByteBuf, ClientServerInputMultiplexer) - Method in class io.rsocket.internal.ServerSetup.DefaultServerSetup
 
acceptRSocketResume(ByteBuf, ClientServerInputMultiplexer) - Method in class io.rsocket.internal.ServerSetup.ResumableServerSetup
 
acceptRSocketSetup(ByteBuf, ClientServerInputMultiplexer, BiFunction<KeepAliveHandler, ClientServerInputMultiplexer, Mono<Void>>) - Method in interface io.rsocket.internal.ServerSetup
 
acceptRSocketSetup(ByteBuf, ClientServerInputMultiplexer, BiFunction<KeepAliveHandler, ClientServerInputMultiplexer, Mono<Void>>) - Method in class io.rsocket.internal.ServerSetup.DefaultServerSetup
 
acceptRSocketSetup(ByteBuf, ClientServerInputMultiplexer, BiFunction<KeepAliveHandler, ClientServerInputMultiplexer, Mono<Void>>) - Method in class io.rsocket.internal.ServerSetup.ResumableServerSetup
 
actuals() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
addClientPlugin(RSocketInterceptor) - Method in class io.rsocket.plugins.PluginRegistry
Deprecated.
addClientPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
Deprecated.
addClientPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
Deprecated.
addConnectionPlugin(DuplexConnectionInterceptor) - Method in class io.rsocket.plugins.PluginRegistry
 
addConnectionPlugin(DuplexConnectionInterceptor) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
addConnectionPlugin(DuplexConnectionInterceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
addRequesterPlugin(RSocketInterceptor) - Method in class io.rsocket.plugins.PluginRegistry
 
addRequesterPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
addRequesterPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
addResponderPlugin(RSocketInterceptor) - Method in class io.rsocket.plugins.PluginRegistry
 
addResponderPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
addResponderPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
addServerPlugin(RSocketInterceptor) - Method in class io.rsocket.plugins.PluginRegistry
Deprecated.
addServerPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
Deprecated.
addServerPlugin(RSocketInterceptor) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
Deprecated.
align(int, int) - Static method in class io.rsocket.internal.BitUtil
Align a value to the next multiple up of alignment.
align(long, int) - Static method in class io.rsocket.internal.jctools.util.Pow2
Align a value to the next multiple up of alignment.
allocate(int) - Static method in class io.rsocket.internal.jctools.queues.CircularArrayOffsetCalculator
 
APPLICATION_ERROR - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
APPLICATION_ERROR - Static variable in class io.rsocket.frame.ErrorType
Application layer logic generating a Reactive Streams onError event.
ApplicationErrorException - Exception in io.rsocket.exceptions
Application layer logic generating a Reactive Streams onError event.
ApplicationErrorException(String) - Constructor for exception io.rsocket.exceptions.ApplicationErrorException
Constructs a new exception with the specified message.
ApplicationErrorException(String, Throwable) - Constructor for exception io.rsocket.exceptions.ApplicationErrorException
Constructs a new exception with the specified message and cause.
apply(ByteBuf) - Method in class io.rsocket.frame.decoder.ZeroCopyPayloadDecoder
 
apply(ClientResume, Throwable) - Method in class io.rsocket.resume.ExponentialBackoffResumeStrategy
 
apply(ClientResume, Throwable) - Method in class io.rsocket.resume.PeriodicResumeStrategy
 
apply(DuplexConnection) - Method in interface io.rsocket.transport.ServerTransport.ConnectionAcceptor
Accept a new DuplexConnection and returns Publisher signifying the end of processing of the connection.
apply(T, U, V) - Method in interface io.rsocket.util.Function3
 
applyClient(RSocket) - Method in class io.rsocket.plugins.PluginRegistry
Deprecated.
applyConnection(DuplexConnectionInterceptor.Type, DuplexConnection) - Method in class io.rsocket.plugins.PluginRegistry
 
applyRequester(RSocket) - Method in class io.rsocket.plugins.PluginRegistry
 
applyResponder(RSocket) - Method in class io.rsocket.plugins.PluginRegistry
 
applyServer(RSocket) - Method in class io.rsocket.plugins.PluginRegistry
Deprecated.
asClientConnection() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
asClientServerConnection() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
asServerConnection() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
asSetupConnection() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
Availability - Interface in io.rsocket
 
availability() - Method in interface io.rsocket.Availability
 
availability() - Method in interface io.rsocket.DuplexConnection
 
availability() - Method in class io.rsocket.lease.LeaseImpl
 
availability() - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
availability() - Method in class io.rsocket.lease.ResponderLeaseHandler.Impl
 
availability() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
availability() - Method in interface io.rsocket.RSocket
 
availability() - Method in class io.rsocket.util.DuplexConnectionProxy
 
availability() - Method in class io.rsocket.util.RSocketProxy
 
available() - Method in class io.rsocket.internal.UnboundedProcessor
 
availableInQueue(long, long) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
availableInQueue(long, long) - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 

B

BaseDuplexConnection - Class in io.rsocket.internal
 
BaseDuplexConnection() - Constructor for class io.rsocket.internal.BaseDuplexConnection
 
BaseMpscLinkedArrayQueue<E> - Class in io.rsocket.internal.jctools.queues
An MPSC array queue which starts at initialCapacity and grows to maxCapacity in linked chunks of the initial size.
BaseMpscLinkedArrayQueue(int) - Constructor for class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
BitUtil - Class in io.rsocket.internal
Miscellaneous useful functions for dealing with low level bits and bytes.
BitUtil() - Constructor for class io.rsocket.internal.BitUtil
 
buildClient(URI) - Method in interface io.rsocket.uri.UriHandler
Returns an implementation of ClientTransport unambiguously mapped to a URI, otherwise Optional.EMPTY.
buildServer(URI) - Method in interface io.rsocket.uri.UriHandler
Returns an implementation of ServerTransport unambiguously mapped to a URI, otherwise Optional.EMPTY.
byteBufAllocator(ByteBufAllocator) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
byteBufAllocator(ByteBufAllocator) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
ByteBufPayload - Class in io.rsocket.util
 

C

CACHE_LINE_LENGTH - Static variable in class io.rsocket.internal.BitUtil
Length of the data blocks used by the CPU cache sub-system in bytes.
CACHE_LINE_SIZE - Static variable in interface io.rsocket.internal.jctools.util.PortableJvmInfo
 
calcElementOffset(long, long) - Static method in class io.rsocket.internal.jctools.queues.CircularArrayOffsetCalculator
 
calcElementOffset(long) - Static method in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
 
calculateShiftForScale(int) - Static method in class io.rsocket.internal.BitUtil
Calculate the shift value to scale a number based on how refs are compressed or not.
cancel() - Method in class io.rsocket.internal.LimitableRequestPublisher
 
cancel() - Method in class io.rsocket.internal.UnboundedProcessor
 
cancel() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
CANCELED - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
CANCELED - Static variable in class io.rsocket.frame.ErrorType
The Responder canceled the request but may have started processing it (similar to REJECTED but doesn't guarantee lack of side-effects).
CanceledException - Exception in io.rsocket.exceptions
The Responder canceled the request but may have started processing it (similar to REJECTED but doesn't guarantee lack of side-effects).
CanceledException(String) - Constructor for exception io.rsocket.exceptions.CanceledException
Constructs a new exception with the specified message.
CanceledException(String, Throwable) - Constructor for exception io.rsocket.exceptions.CanceledException
Constructs a new exception with the specified message and cause.
CancelFrameFlyweight - Class in io.rsocket.frame
 
canHaveData() - Method in enum io.rsocket.frame.FrameType
Whether the frame type can have data.
canHaveMetadata() - Method in enum io.rsocket.frame.FrameType
Whether the frame type can have metadata
capacity() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
capacity() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
capacity() - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
checkGreaterThanOrEqual(int, int, String) - Static method in class io.rsocket.internal.jctools.util.RangeUtil
 
checkLessThan(int, int, String) - Static method in class io.rsocket.internal.jctools.util.RangeUtil
 
checkLessThanOrEqual(int, long, String) - Static method in class io.rsocket.internal.jctools.util.RangeUtil
 
checkMtu(int) - Static method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
checkPositive(long, String) - Static method in class io.rsocket.internal.jctools.util.RangeUtil
 
checkPositiveOrZero(int, String) - Static method in class io.rsocket.internal.jctools.util.RangeUtil
 
CircularArrayOffsetCalculator - Class in io.rsocket.internal.jctools.queues
 
CircularArrayOffsetCalculator() - Constructor for class io.rsocket.internal.jctools.queues.CircularArrayOffsetCalculator
 
clear() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
clear() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
clear() - Method in class io.rsocket.internal.UnboundedProcessor
 
clientForUri(String) - Static method in class io.rsocket.uri.UriTransportRegistry
 
ClientKeepAliveSupport(ByteBufAllocator, int, int) - Constructor for class io.rsocket.keepalive.KeepAliveSupport.ClientKeepAliveSupport
 
ClientResume - Class in io.rsocket.resume
 
ClientResume(Duration, ByteBuf) - Constructor for class io.rsocket.resume.ClientResume
 
ClientRSocketFactory() - Constructor for class io.rsocket.RSocketFactory.ClientRSocketFactory
 
ClientRSocketSession - Class in io.rsocket.resume
 
ClientRSocketSession(DuplexConnection, ByteBufAllocator, Duration, Supplier<ResumeStrategy>, ResumableFramesStore, Duration, boolean) - Constructor for class io.rsocket.resume.ClientRSocketSession
 
ClientServerInputMultiplexer - Class in io.rsocket.internal
DuplexConnection.receive() is a single stream on which the following type of frames arrive: Frames for streams initiated by the initiator of the connection (client).
ClientServerInputMultiplexer(DuplexConnection) - Constructor for class io.rsocket.internal.ClientServerInputMultiplexer
 
ClientServerInputMultiplexer(DuplexConnection, PluginRegistry, boolean) - Constructor for class io.rsocket.internal.ClientServerInputMultiplexer
 
ClientSetup - Interface in io.rsocket.internal
 
ClientSetup.DefaultClientSetup - Class in io.rsocket.internal
 
ClientSetup.ResumableClientSetup - Class in io.rsocket.internal
 
ClientTransport - Interface in io.rsocket.transport
A client contract for writing transports of RSocket.
Clock - Class in io.rsocket.util
Abstraction to get current time and durations.
Closeable - Interface in io.rsocket
 
CollectionUtil - Class in io.rsocket.internal
Utility functions for collection objects.
CollectionUtil() - Constructor for class io.rsocket.internal.CollectionUtil
 
CompositeMetadata - Class in io.rsocket.metadata
An Iterable wrapper around a ByteBuf that exposes metadata entry information at each decoding step.
CompositeMetadata(ByteBuf, boolean) - Constructor for class io.rsocket.metadata.CompositeMetadata
 
CompositeMetadata.Entry - Interface in io.rsocket.metadata
An entry in the CompositeMetadata.
CompositeMetadata.ExplicitMimeTimeEntry - Class in io.rsocket.metadata
An CompositeMetadata.Entry backed by an explicitly declared MIME type.
CompositeMetadata.ReservedMimeTypeEntry - Class in io.rsocket.metadata
An CompositeMetadata.Entry backed by a WellKnownMimeType entry, but one that is not understood by this implementation.
CompositeMetadata.WellKnownMimeTypeEntry - Class in io.rsocket.metadata
CompositeMetadataFlyweight - Class in io.rsocket.metadata
A flyweight class that can be used to encode/decode composite metadata information to/from ByteBuf.
compoundKey(int, int) - Static method in class io.rsocket.internal.Hashing
Combined two 32 bit keys into a 64-bit compound.
computeNextEntryIndex(int, ByteBuf, ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
 
connect() - Static method in class io.rsocket.RSocketFactory
Creates a factory that establishes client connections to other RSockets.
connect(int) - Method in interface io.rsocket.transport.ClientTransport
Returns a Publisher, every subscription to which returns a single DuplexConnection.
connection() - Method in interface io.rsocket.internal.ClientSetup
 
connection() - Method in class io.rsocket.internal.ClientSetup.DefaultClientSetup
 
connection() - Method in class io.rsocket.internal.ClientSetup.ResumableClientSetup
 
CONNECTION_CLOSE - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
CONNECTION_CLOSE - Static variable in class io.rsocket.frame.ErrorType
The connection is being terminated.
CONNECTION_ERROR - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
CONNECTION_ERROR - Static variable in class io.rsocket.frame.ErrorType
The connection is being terminated.
ConnectionCloseException - Exception in io.rsocket.exceptions
The connection is being terminated.
ConnectionCloseException(String) - Constructor for exception io.rsocket.exceptions.ConnectionCloseException
Constructs a new exception with the specified message.
ConnectionCloseException(String, Throwable) - Constructor for exception io.rsocket.exceptions.ConnectionCloseException
Constructs a new exception with the specified message and cause.
ConnectionErrorException - Exception in io.rsocket.exceptions
The connection is being terminated.
ConnectionErrorException(String) - Constructor for exception io.rsocket.exceptions.ConnectionErrorException
Constructs a new exception with the specified message.
ConnectionErrorException(String, Throwable) - Constructor for exception io.rsocket.exceptions.ConnectionErrorException
Constructs a new exception with the specified message and cause.
ConnectionSetupPayload - Class in io.rsocket
Exposed to server for determination of ResponderRSocket based on mime types and SETUP metadata/data
ConnectionSetupPayload() - Constructor for class io.rsocket.ConnectionSetupPayload
 
ConnectionUtils - Class in io.rsocket.util
 
ConnectionUtils() - Constructor for class io.rsocket.util.ConnectionUtils
 
containsKey(int) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
containsKey(Object) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
containsValue(Object) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
continueWith(Mono<DuplexConnection>) - Method in class io.rsocket.resume.ClientRSocketSession
 
continueWith(T) - Method in interface io.rsocket.resume.RSocketSession
 
continueWith(DuplexConnection) - Method in class io.rsocket.resume.ServerRSocketSession
 
CPUs - Static variable in interface io.rsocket.internal.jctools.util.PortableJvmInfo
 
create(ByteBuf) - Static method in class io.rsocket.ConnectionSetupPayload
 
create() - Static method in class io.rsocket.internal.UnicastMonoProcessor
 
create(int, int, ByteBuf) - Static method in interface io.rsocket.lease.Lease
 
create(int, int) - Static method in interface io.rsocket.lease.Lease
 
create() - Static method in class io.rsocket.lease.Leases
 
create(String) - Static method in class io.rsocket.util.ByteBufPayload
Static factory method for a text payload.
create(String, String) - Static method in class io.rsocket.util.ByteBufPayload
Static factory method for a text payload.
create(CharSequence, Charset) - Static method in class io.rsocket.util.ByteBufPayload
 
create(CharSequence, Charset, CharSequence, Charset) - Static method in class io.rsocket.util.ByteBufPayload
 
create(byte[]) - Static method in class io.rsocket.util.ByteBufPayload
 
create(byte[], byte[]) - Static method in class io.rsocket.util.ByteBufPayload
 
create(ByteBuffer) - Static method in class io.rsocket.util.ByteBufPayload
 
create(ByteBuffer, ByteBuffer) - Static method in class io.rsocket.util.ByteBufPayload
 
create(ByteBuf) - Static method in class io.rsocket.util.ByteBufPayload
 
create(ByteBuf, ByteBuf) - Static method in class io.rsocket.util.ByteBufPayload
 
create(Payload) - Static method in class io.rsocket.util.ByteBufPayload
 
create(CharSequence) - Static method in class io.rsocket.util.DefaultPayload
Static factory method for a text payload.
create(CharSequence, CharSequence) - Static method in class io.rsocket.util.DefaultPayload
Static factory method for a text payload.
create(CharSequence, Charset) - Static method in class io.rsocket.util.DefaultPayload
 
create(CharSequence, Charset, CharSequence, Charset) - Static method in class io.rsocket.util.DefaultPayload
 
create(byte[]) - Static method in class io.rsocket.util.DefaultPayload
 
create(byte[], byte[]) - Static method in class io.rsocket.util.DefaultPayload
 
create(ByteBuffer) - Static method in class io.rsocket.util.DefaultPayload
 
create(ByteBuffer, ByteBuffer) - Static method in class io.rsocket.util.DefaultPayload
 
create(ByteBuf) - Static method in class io.rsocket.util.DefaultPayload
 
create(ByteBuf, ByteBuf) - Static method in class io.rsocket.util.DefaultPayload
 
create(Payload) - Static method in class io.rsocket.util.DefaultPayload
 
createRecycler(Function<Recycler.Handle<T>, T>) - Static method in class io.rsocket.util.RecyclerFactory
Creates a new Recycler.
CURRENT_VERSION - Static variable in class io.rsocket.frame.SetupFrameFlyweight
 
currentConsumerIndex() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
currentConsumerIndex() - Method in interface io.rsocket.internal.jctools.queues.QueueProgressIndicators
This method has no concurrent visibility semantics.
currentContext() - Method in class io.rsocket.internal.UnboundedProcessor
 
currentContext() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
currentProducerIndex() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
currentProducerIndex() - Method in interface io.rsocket.internal.jctools.queues.QueueProgressIndicators
This method has no concurrent visibility semantics.

D

data(ByteBuf) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.ExtensionFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.KeepAliveFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.RequestChannelFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.RequestFireAndForgetFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.RequestResponseFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
data(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
data() - Method in interface io.rsocket.Payload
Returns the Payloads' data without slicing if possible.
data() - Method in class io.rsocket.util.ByteBufPayload
 
data() - Method in class io.rsocket.util.DefaultPayload
 
data() - Method in class io.rsocket.util.EmptyPayload
 
dataMimeType() - Method in class io.rsocket.ConnectionSetupPayload
 
dataMimeType(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
dataMimeType(String) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
dataUtf8(ByteBuf) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
deallocate() - Method in class io.rsocket.util.ByteBufPayload
 
decodeMimeAndContentBuffersSlices(ByteBuf, int, boolean) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Decode the next metadata entry (a mime header + content pair of ByteBuf) from a ByteBuf that contains at least enough bytes for one more such entry.
decodeMimeIdFromMimeBuffer(ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Decode a byte compressed mime id from a ByteBuf, assuming said buffer properly contains such an id.
decodeMimeTypeFromMimeBuffer(ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Decode a CharSequence custome mime type from a ByteBuf, assuming said buffer properly contains such a mime type.
DEFAULT - Static variable in interface io.rsocket.frame.decoder.PayloadDecoder
 
DEFAULT_CAPACITY - Static variable in class io.rsocket.internal.SynchronizedIntObjectHashMap
Default initial capacity.
DEFAULT_LOAD_FACTOR - Static variable in class io.rsocket.internal.Hashing
Default load factor to be used in open addressing hashed data structures.
DEFAULT_LOAD_FACTOR - Static variable in class io.rsocket.internal.SynchronizedIntObjectHashMap
Default load factor.
DefaultClientSetup(DuplexConnection) - Constructor for class io.rsocket.internal.ClientSetup.DefaultClientSetup
 
DefaultKeepAliveHandler(Closeable) - Constructor for class io.rsocket.keepalive.KeepAliveHandler.DefaultKeepAliveHandler
 
DefaultPayload - Class in io.rsocket.util
An implementation of Payload.
defaultPlugins() - Static method in class io.rsocket.plugins.Plugins
 
DefaultServerSetup(ByteBufAllocator) - Constructor for class io.rsocket.internal.ServerSetup.DefaultServerSetup
 
delegate() - Method in class io.rsocket.util.DuplexConnectionProxy
 
DISABLE_FRAME_TYPE_CHECK - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
 
disconnect() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
DisposableUtils - Class in io.rsocket.util
Utilities for working with the Disposable type.
dispose() - Method in class io.rsocket.AbstractRSocket
 
dispose() - Method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
dispose() - Method in class io.rsocket.internal.BaseDuplexConnection
 
dispose() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
dispose() - Method in interface io.rsocket.internal.ServerSetup
 
dispose() - Method in class io.rsocket.internal.ServerSetup.ResumableServerSetup
 
dispose() - Method in class io.rsocket.internal.UnboundedProcessor
 
dispose() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
dispose() - Method in interface io.rsocket.lease.RequesterLeaseHandler
 
dispose() - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
dispose() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
dispose() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
dispose() - Method in interface io.rsocket.resume.RSocketSession
 
dispose() - Method in class io.rsocket.resume.SessionManager
 
dispose() - Method in class io.rsocket.util.DuplexConnectionProxy
 
dispose() - Method in class io.rsocket.util.RSocketProxy
 
disposeQuietly(Disposable...) - Static method in class io.rsocket.util.DisposableUtils
Calls the Disposable.dispose() method if the instance is not null.
doOnClose() - Method in class io.rsocket.internal.BaseDuplexConnection
 
downstreamCount() - Method in class io.rsocket.internal.UnboundedProcessor
 
downstreamCount() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
drain(MessagePassingQueue.Consumer<E>) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
drain(MessagePassingQueue.Consumer<E>, int) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
drain(MessagePassingQueue.Consumer<E>, MessagePassingQueue.WaitStrategy, MessagePassingQueue.ExitCondition) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
drain(MessagePassingQueue.Consumer<T>) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
drain(MessagePassingQueue.Consumer<T>, int) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
drain(MessagePassingQueue.Consumer<T>, MessagePassingQueue.WaitStrategy, MessagePassingQueue.ExitCondition) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
drain(MessagePassingQueue.Consumer<E>) - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
drain() - Method in class io.rsocket.internal.UnboundedProcessor
 
DuplexConnection - Interface in io.rsocket
Represents a connection with input/output that the protocol uses.
DuplexConnectionInterceptor - Interface in io.rsocket.plugins
 
DuplexConnectionInterceptor.Type - Enum in io.rsocket.plugins
 
DuplexConnectionProxy - Class in io.rsocket.util
 
DuplexConnectionProxy(DuplexConnection) - Constructor for class io.rsocket.util.DuplexConnectionProxy
 

E

elapsedSince(long) - Static method in class io.rsocket.util.Clock
 
EMPTY_BUFFER - Static variable in class io.rsocket.util.DefaultPayload
 
EmptyPayload - Class in io.rsocket.util
 
encode(ByteBufAllocator, int) - Static method in class io.rsocket.frame.CancelFrameFlyweight
 
encode(ByteBufAllocator, int, Throwable, ByteBuf) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
encode(ByteBufAllocator, int, Throwable) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
encode(ByteBufAllocator, int, int, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.ExtensionFrameFlyweight
 
encode(ByteBufAllocator, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.FragmentationFlyweight
 
encode(ByteBufAllocator, ByteBuf, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.FragmentationFlyweight
 
encode(ByteBufAllocator, int, FrameType, int) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
encode(ByteBufAllocator, int, ByteBuf) - Static method in class io.rsocket.frame.FrameLengthFlyweight
 
encode(ByteBufAllocator, boolean, long, ByteBuf) - Static method in class io.rsocket.frame.KeepAliveFrameFlyweight
 
encode(ByteBufAllocator, int, int, ByteBuf) - Static method in class io.rsocket.frame.LeaseFrameFlyweight
 
encode(ByteBufAllocator, ByteBuf) - Static method in class io.rsocket.frame.MetadataPushFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, boolean, boolean, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, boolean, boolean, Payload) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, boolean, long, Payload) - Static method in class io.rsocket.frame.RequestChannelFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, boolean, long, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.RequestChannelFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, Payload) - Static method in class io.rsocket.frame.RequestFireAndForgetFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.RequestFireAndForgetFrameFlyweight
 
encode(ByteBufAllocator, int, long) - Static method in class io.rsocket.frame.RequestNFrameFlyweight
 
encode(ByteBufAllocator, int, int) - Static method in class io.rsocket.frame.RequestNFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, Payload) - Static method in class io.rsocket.frame.RequestResponseFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.RequestResponseFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, long, Payload) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, int, Payload) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, long, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
encode(ByteBufAllocator, int, boolean, int, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
encode(ByteBufAllocator, ByteBuf, long, long) - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
encode(ByteBufAllocator, long) - Static method in class io.rsocket.frame.ResumeOkFrameFlyweight
 
encode(ByteBufAllocator, boolean, int, int, String, String, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
encode(ByteBufAllocator, boolean, int, int, ByteBuf, String, String, ByteBuf, ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
encode(int, int) - Static method in class io.rsocket.frame.VersionFlyweight
 
encodeAndAddMetadata(CompositeByteBuf, ByteBufAllocator, String, ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Encode a new sub-metadata information into a composite metadata buffer, without checking if the String can be matched with a well known compressable mime type.
encodeAndAddMetadata(CompositeByteBuf, ByteBufAllocator, WellKnownMimeType, ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Encode a new sub-metadata information into a composite metadata buffer.
encodeAndAddMetadataWithCompression(CompositeByteBuf, ByteBufAllocator, String, ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Encode a new sub-metadata information into a composite metadata buffer, first verifying if the passed String matches a WellKnownMimeType (in which case it will be encoded in a compressed fashion using the mime id of that type).
encodeComplete(ByteBufAllocator, int) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
encodeNext(ByteBufAllocator, int, Payload) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
encodeNextComplete(ByteBufAllocator, int, Payload) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
encodeUnsignedMedium(ByteBuf, int) - Static method in class io.rsocket.util.NumberUtils
Encode an unsigned medium integer on 3 bytes / 24 bits.
ensureFrameType(FrameType, ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
entries() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
entrySet() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
equals(Object) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
errorCode() - Method in exception io.rsocket.exceptions.ApplicationErrorException
 
errorCode() - Method in exception io.rsocket.exceptions.CanceledException
 
errorCode() - Method in exception io.rsocket.exceptions.ConnectionCloseException
 
errorCode() - Method in exception io.rsocket.exceptions.ConnectionErrorException
 
errorCode() - Method in exception io.rsocket.exceptions.InvalidException
 
errorCode() - Method in exception io.rsocket.exceptions.InvalidSetupException
 
errorCode() - Method in exception io.rsocket.exceptions.RejectedException
 
errorCode() - Method in exception io.rsocket.exceptions.RejectedResumeException
 
errorCode() - Method in exception io.rsocket.exceptions.RejectedSetupException
 
errorCode() - Method in exception io.rsocket.exceptions.RSocketException
Returns the RSocket error code represented by this exception
errorCode() - Method in exception io.rsocket.exceptions.UnsupportedSetupException
 
errorCode(ByteBuf) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
errorCodeFromException(Throwable) - Static method in class io.rsocket.frame.ErrorFrameFlyweight
 
errorConsumer(Consumer<Throwable>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
errorConsumer(Consumer<Throwable>) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
ErrorFrameFlyweight - Class in io.rsocket.frame
 
ErrorFrameFlyweight() - Constructor for class io.rsocket.frame.ErrorFrameFlyweight
 
ErrorType - Class in io.rsocket.frame
The types of Error that can be set.
evenHash(int, int) - Static method in class io.rsocket.internal.Hashing
Generate an even hash for a int value.
evenHash(long, int) - Static method in class io.rsocket.internal.Hashing
Generate an even hash for a long value.
Exceptions - Class in io.rsocket.exceptions
Utility class that generates an exception from a frame.
expiry() - Method in interface io.rsocket.lease.Lease
Absolute time since epoch at which this lease will expire.
expiry() - Method in class io.rsocket.lease.LeaseImpl
 
ExplicitMimeTimeEntry(ByteBuf, String) - Constructor for class io.rsocket.metadata.CompositeMetadata.ExplicitMimeTimeEntry
 
ExponentialBackoffResumeStrategy - Class in io.rsocket.resume
 
ExponentialBackoffResumeStrategy(Duration, Duration, int) - Constructor for class io.rsocket.resume.ExponentialBackoffResumeStrategy
 
extendedType(ByteBuf) - Static method in class io.rsocket.frame.ExtensionFrameFlyweight
 
ExtensionFrameFlyweight - Class in io.rsocket.frame
 

F

fieldOffset(Class, String) - Static method in class io.rsocket.internal.jctools.util.UnsafeAccess
 
fill(MessagePassingQueue.Supplier<E>) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
fill(MessagePassingQueue.Supplier<E>, int) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
fill(MessagePassingQueue.Supplier<E>, MessagePassingQueue.WaitStrategy, MessagePassingQueue.ExitCondition) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
fill(MessagePassingQueue.Supplier<T>) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
fill(MessagePassingQueue.Supplier<T>, int) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
fill(MessagePassingQueue.Supplier<T>, MessagePassingQueue.WaitStrategy, MessagePassingQueue.ExitCondition) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
fill(MessagePassingQueue.Supplier<E>) - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
fillInStackTrace() - Method in exception io.rsocket.exceptions.MissingLeaseException
 
findNextPositivePowerOfTwo(int) - Static method in class io.rsocket.internal.BitUtil
Fast method of finding the next power of 2 greater than or equal to the supplied value.
fireAndForget(Payload) - Method in class io.rsocket.AbstractRSocket
 
fireAndForget(Payload) - Method in interface io.rsocket.RSocket
Fire and Forget interaction model of RSocket.
fireAndForget(Payload) - Method in class io.rsocket.util.MultiSubscriberRSocket
 
fireAndForget(Payload) - Method in class io.rsocket.util.RSocketProxy
 
firstAvailableClientPos(ByteBuf) - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
flags(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
FLAGS_C - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
(C)omplete: bit to indicate stream completion (Subscriber.onComplete())
FLAGS_F - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
(F)ollows: More fragments follow this fragment (in case of fragmented REQUEST_x or PAYLOAD frames)
FLAGS_I - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
(I)gnore flag: a value of 0 indicates the protocol can't ignore this frame
FLAGS_KEEPALIVE_R - Static variable in class io.rsocket.frame.KeepAliveFrameFlyweight
(R)espond: Set by the sender of the KEEPALIVE, to which the responder MUST reply with a KEEPALIVE without the R flag set
FLAGS_M - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
(M)etadata flag: a value of 1 indicates the frame contains metadata
FLAGS_N - Static variable in class io.rsocket.frame.FrameHeaderFlyweight
(N)ext: bit to indicate payload or metadata present (Subscriber.onNext(Object))
FLAGS_RESUME_ENABLE - Static variable in class io.rsocket.frame.SetupFrameFlyweight
A flag used to indicate that the client requires connection resumption, if possible (the frame contains a Resume Identification Token)
FLAGS_WILL_HONOR_LEASE - Static variable in class io.rsocket.frame.SetupFrameFlyweight
A flag used to indicate that the client will honor LEASE sent by the server
fragment(int) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
fragment(int) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
FragmentationDuplexConnection - Class in io.rsocket.fragmentation
A DuplexConnection implementation that fragments and reassembles ByteBufs.
FragmentationDuplexConnection(DuplexConnection, ByteBufAllocator, int, boolean, String) - Constructor for class io.rsocket.fragmentation.FragmentationDuplexConnection
 
FragmentationFlyweight - Class in io.rsocket.frame
FragmentationFlyweight is used to re-assemble frames
FragmentationFlyweight() - Constructor for class io.rsocket.frame.FragmentationFlyweight
 
frame(ByteBuf) - Static method in class io.rsocket.frame.FrameLengthFlyweight
 
FRAME_LENGTH_MASK - Static variable in class io.rsocket.frame.FrameLengthFlyweight
 
FRAME_LENGTH_SIZE - Static variable in class io.rsocket.frame.FrameLengthFlyweight
 
frameDecoder(PayloadDecoder) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
frameDecoder(PayloadDecoder) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
FrameHeaderFlyweight - Class in io.rsocket.frame
Per connection frame flyweight.
frameImpliedPosition() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
frameImpliedPosition() - Method in interface io.rsocket.resume.ResumableFramesStore
 
FrameLengthFlyweight - Class in io.rsocket.frame
Some transports like TCP aren't framed, and require a length.
framePosition() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
framePosition() - Method in interface io.rsocket.resume.ResumableFramesStore
 
frameType(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
FrameType - Enum in io.rsocket.frame
Types of Frame that can be sent.
FrameUtil - Class in io.rsocket.frame
 
from(ByteBuf) - Static method in class io.rsocket.exceptions.Exceptions
Create a RSocketException from a Frame that matches the error code it contains.
fromEncodedType(int) - Static method in enum io.rsocket.frame.FrameType
Returns the FrameType that matches the specified encodedType.
fromHex(String) - Static method in class io.rsocket.internal.BitUtil
Generate a byte array from a string that is the hex representation of the given byte array.
fromHexByteArray(byte[]) - Static method in class io.rsocket.internal.BitUtil
Generate a byte array from the hex representation of the given byte array.
fromIdentifier(int) - Static method in enum io.rsocket.metadata.WellKnownMimeType
Find the WellKnownMimeType for the given identifier (as an int).
fromServices() - Static method in class io.rsocket.uri.UriTransportRegistry
 
fromString(String) - Static method in enum io.rsocket.metadata.WellKnownMimeType
Find the WellKnownMimeType for the given String representation.
Function3<T,U,V,R> - Interface in io.rsocket.util
 

G

generateRandomisedId() - Static method in class io.rsocket.internal.BitUtil
Generate a randomised integer over [Integer.MIN_VALUE, Integer.MAX_VALUE].
generateResumeToken() - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
get() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue.Supplier
 
get(int) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
get(Object) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
get(ByteBuf) - Method in class io.rsocket.resume.SessionManager
 
getAllowedRequests() - Method in interface io.rsocket.lease.Lease
Number of requests allowed by this lease.
getAllowedRequests() - Method in class io.rsocket.lease.LeaseImpl
 
getAsLong() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
getBufferSize() - Method in class io.rsocket.internal.UnboundedProcessor
 
getContent() - Method in interface io.rsocket.metadata.CompositeMetadata.Entry
Returns the un-decoded content of the CompositeMetadata.Entry.
getContent() - Method in class io.rsocket.metadata.CompositeMetadata.ExplicitMimeTimeEntry
 
getContent() - Method in class io.rsocket.metadata.CompositeMetadata.ReservedMimeTypeEntry
 
getContent() - Method in class io.rsocket.metadata.CompositeMetadata.WellKnownMimeTypeEntry
 
getCurrentBufferCapacity(long) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
getCurrentBufferCapacity(long) - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
getData() - Method in interface io.rsocket.Payload
 
getData() - Method in class io.rsocket.util.DefaultPayload
 
getDataUtf8() - Method in interface io.rsocket.Payload
 
getEncodedType() - Method in enum io.rsocket.frame.FrameType
Returns the encoded type.
getError() - Method in class io.rsocket.internal.UnboundedProcessor
 
getError() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
getFlags() - Method in class io.rsocket.ConnectionSetupPayload
 
getIdentifier() - Method in enum io.rsocket.metadata.WellKnownMimeType
 
getMetadata() - Method in interface io.rsocket.lease.Lease
Metadata for the lease.
getMetadata() - Method in class io.rsocket.lease.LeaseImpl
 
getMetadata() - Method in interface io.rsocket.Payload
 
getMetadata() - Method in class io.rsocket.util.DefaultPayload
 
getMetadataUtf8() - Method in interface io.rsocket.Payload
 
getMimeType() - Method in interface io.rsocket.metadata.CompositeMetadata.Entry
Returns the MIME type of the entry, if it can be decoded.
getMimeType() - Method in class io.rsocket.metadata.CompositeMetadata.ExplicitMimeTimeEntry
 
getMimeType() - Method in class io.rsocket.metadata.CompositeMetadata.ReservedMimeTypeEntry
Returns the MIME type of the entry, if it can be decoded.
getMimeType() - Method in class io.rsocket.metadata.CompositeMetadata.WellKnownMimeTypeEntry
 
getNextBufferSize(E[]) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
getNextBufferSize(E[]) - Method in class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
getOrDefault(Map<K, V>, K, Function<K, V>) - Static method in class io.rsocket.internal.CollectionUtil
A getOrDefault that doesn't create garbage if its suppler is non-capturing.
getPrefetch() - Method in class io.rsocket.internal.SwitchTransformFlux
Deprecated.
 
getPrefetch() - Method in class io.rsocket.internal.UnboundedProcessor
 
getRemainingTimeToLiveMillis(long) - Method in interface io.rsocket.lease.Lease
Number of milliseconds that this lease is still valid from now.
getStartingAllowedRequests() - Method in interface io.rsocket.lease.Lease
Initial number of requests allowed by this lease.
getStartingAllowedRequests() - Method in class io.rsocket.lease.LeaseImpl
 
getString() - Method in enum io.rsocket.metadata.WellKnownMimeType
 
getTickPeriod() - Method in class io.rsocket.keepalive.KeepAliveSupport.KeepAlive
 
getTimeout() - Method in class io.rsocket.keepalive.KeepAliveSupport.KeepAlive
 
getTimeToLiveMillis() - Method in interface io.rsocket.lease.Lease
Number of milliseconds that this lease is valid from the time it is received.
getTimeToLiveMillis() - Method in class io.rsocket.lease.LeaseImpl
 
getType() - Method in class io.rsocket.metadata.CompositeMetadata.ReservedMimeTypeEntry
Returns the reserved, but unknown WellKnownMimeType for this entry.
getType() - Method in class io.rsocket.metadata.CompositeMetadata.WellKnownMimeTypeEntry
Returns the WellKnownMimeType for this entry.
getValuesCopy() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 

H

hasDownstreams() - Method in class io.rsocket.internal.UnboundedProcessor
 
hasDownstreams() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
hasEntry(ByteBuf, int) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Returns whether there is another entry available at a given index
hasFollows(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
hash(int) - Static method in class io.rsocket.internal.Hashing
Generate a hash for an int value.
hash(long) - Static method in class io.rsocket.internal.Hashing
Generate a hash for an long value.
hash(int, int) - Static method in class io.rsocket.internal.Hashing
Generate a hash for a int value.
hash(K, int) - Static method in class io.rsocket.internal.Hashing
Generate a hash for a K value.
hash(long, int) - Static method in class io.rsocket.internal.Hashing
Generate a hash for a long value.
hashCode() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
Hashing - Class in io.rsocket.internal
Hashing functions for applying to integers.
Hashing() - Constructor for class io.rsocket.internal.Hashing
 
hasInitialRequestN() - Method in enum io.rsocket.frame.FrameType
Whether the frame type starts with an initial requestN.
hasMetadata(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
hasMetadata() - Method in interface io.rsocket.Payload
Returns whether the payload has metadata, useful for tell if metadata is empty or not present.
hasMetadata() - Method in class io.rsocket.util.ByteBufPayload
 
hasMetadata() - Method in class io.rsocket.util.DefaultPayload
 
hasMetadata() - Method in class io.rsocket.util.EmptyPayload
 
honorLease(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
humanReadableVersion(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 

I

idle(int) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue.WaitStrategy
 
Impl(String, Consumer<Flux<Lease>>) - Constructor for class io.rsocket.lease.RequesterLeaseHandler.Impl
 
Impl(String, ByteBufAllocator, Function<Optional<T>, Flux<Lease>>, Consumer<Throwable>, Optional<T>) - Constructor for class io.rsocket.lease.ResponderLeaseHandler.Impl
 
impliedPosition() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
impliedPosition() - Method in interface io.rsocket.resume.ResumeStateHolder
 
increaseInternalLimit(long) - Method in class io.rsocket.internal.LimitableRequestPublisher
 
IndexedQueueSizeUtil - Class in io.rsocket.internal.jctools.queues
 
IndexedQueueSizeUtil() - Constructor for class io.rsocket.internal.jctools.queues.IndexedQueueSizeUtil
 
IndexedQueueSizeUtil.IndexedQueue - Interface in io.rsocket.internal.jctools.queues
 
initialRequestN(ByteBuf) - Static method in class io.rsocket.frame.RequestChannelFrameFlyweight
 
initialRequestN(ByteBuf) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
InMemoryResumableFramesStore - Class in io.rsocket.resume
 
InMemoryResumableFramesStore(String, int) - Constructor for class io.rsocket.resume.InMemoryResumableFramesStore
 
INSTANCE - Static variable in class io.rsocket.util.EmptyPayload
 
interceptClient(RSocketInterceptor) - Static method in class io.rsocket.plugins.Plugins
 
interceptConnection(DuplexConnectionInterceptor) - Static method in class io.rsocket.plugins.Plugins
 
interceptServer(RSocketInterceptor) - Static method in class io.rsocket.plugins.Plugins
 
InternalAPI - Annotation Type in io.rsocket.internal.jctools.util
This annotation marks classes and methods which may be public for any reason (to support better testing or reduce code duplication) but are not intended as public API and may change between releases without the change being considered a breaking API change (a major release).
INVALID - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
INVALID - Static variable in class io.rsocket.frame.ErrorType
The request is invalid.
INVALID_SETUP - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
INVALID_SETUP - Static variable in class io.rsocket.frame.ErrorType
The Setup frame is invalid for the server (it could be that the client is too recent for the old server).
InvalidException - Exception in io.rsocket.exceptions
The request is invalid.
InvalidException(String) - Constructor for exception io.rsocket.exceptions.InvalidException
Constructs a new exception with the specified message.
InvalidException(String, Throwable) - Constructor for exception io.rsocket.exceptions.InvalidException
Constructs a new exception with the specified message and cause.
InvalidSetupException - Exception in io.rsocket.exceptions
The Setup frame is invalid for the server (it could be that the client is too recent for the old server).
InvalidSetupException(String) - Constructor for exception io.rsocket.exceptions.InvalidSetupException
Constructs a new exception with the specified message.
InvalidSetupException(String, Throwable) - Constructor for exception io.rsocket.exceptions.InvalidSetupException
Constructs a new exception with the specified message and cause.
io.rsocket - package io.rsocket
 
io.rsocket.buffer - package io.rsocket.buffer
 
io.rsocket.exceptions - package io.rsocket.exceptions
The hierarchy of exceptions that can be returned by the API
io.rsocket.fragmentation - package io.rsocket.fragmentation
Support for frame fragmentation and reassembly.
io.rsocket.frame - package io.rsocket.frame
 
io.rsocket.frame.decoder - package io.rsocket.frame.decoder
 
io.rsocket.internal - package io.rsocket.internal
Internal package and must not be used outside this project.
io.rsocket.internal.jctools.queues - package io.rsocket.internal.jctools.queues
 
io.rsocket.internal.jctools.util - package io.rsocket.internal.jctools.util
 
io.rsocket.keepalive - package io.rsocket.keepalive
 
io.rsocket.lease - package io.rsocket.lease
 
io.rsocket.metadata - package io.rsocket.metadata
 
io.rsocket.plugins - package io.rsocket.plugins
 
io.rsocket.resume - package io.rsocket.resume
 
io.rsocket.transport - package io.rsocket.transport
 
io.rsocket.uri - package io.rsocket.uri
 
io.rsocket.util - package io.rsocket.util
 
isAligned(long, int) - Static method in class io.rsocket.internal.BitUtil
Is an address aligned on a boundary.
isCancelled() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isDisposed() - Method in class io.rsocket.AbstractRSocket
 
isDisposed() - Method in class io.rsocket.internal.BaseDuplexConnection
 
isDisposed() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
isDisposed() - Method in class io.rsocket.internal.UnboundedProcessor
 
isDisposed() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isDisposed() - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
isDisposed() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
isDisposed() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
isDisposed() - Method in interface io.rsocket.resume.RSocketSession
 
isDisposed() - Method in class io.rsocket.util.DuplexConnectionProxy
 
isDisposed() - Method in class io.rsocket.util.RSocketProxy
 
isEmpty() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
isEmpty(IndexedQueueSizeUtil.IndexedQueue) - Static method in class io.rsocket.internal.jctools.queues.IndexedQueueSizeUtil
 
isEmpty() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
isEmpty() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
isEmpty() - Method in class io.rsocket.internal.UnboundedProcessor
 
isEmpty() - Method in interface io.rsocket.lease.Lease
Checks if the lease is empty(default value if no lease was received yet)
isError() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isEven(int) - Static method in class io.rsocket.internal.BitUtil
Is a number even.
isExpired() - Method in interface io.rsocket.lease.Lease
Checks if the lease is expired now.
isExpired(long) - Method in interface io.rsocket.lease.Lease
Checks if the lease is expired for the passed now.
isFragmentable() - Method in enum io.rsocket.frame.FrameType
Whether the frame type is fragmentable.
isPowerOfTwo(int) - Static method in class io.rsocket.internal.BitUtil
Is a value a positive power of 2.
isPowerOfTwo(int) - Static method in class io.rsocket.internal.jctools.util.Pow2
 
isRequestType() - Method in enum io.rsocket.frame.FrameType
Whether the frame type is a request type.
isScanAvailable() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isSuccess() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isSupportedVersion(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
isTerminated() - Method in class io.rsocket.internal.UnboundedProcessor
 
isTerminated() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
isValid() - Method in interface io.rsocket.lease.Lease
Checks if the lease has not expired and there are allowed requests available
isValid() - Method in class io.rsocket.lease.LeaseImpl
 
isWellKnownMimeType(ByteBuf) - Static method in class io.rsocket.metadata.CompositeMetadataFlyweight
Returns whether the header represents a well-known MIME type.
iterator() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
Get an iterator for this queue.
iterator() - Method in class io.rsocket.metadata.CompositeMetadata
An Iterator that lazily decodes CompositeMetadata.Entry in this composite metadata.

K

KeepAlive(Duration, Duration) - Constructor for class io.rsocket.keepalive.KeepAliveSupport.KeepAlive
 
keepAlive() - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
Deprecated.
keepAlive(Duration, Duration, int) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
keepAliveAckTimeout(Duration) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
KeepAliveFrameFlyweight - Class in io.rsocket.frame
 
KeepAliveFramesAcceptor - Interface in io.rsocket.keepalive
 
keepAliveHandler() - Method in class io.rsocket.internal.ClientSetup.DefaultClientSetup
 
keepAliveHandler() - Method in interface io.rsocket.internal.ClientSetup
 
keepAliveHandler() - Method in class io.rsocket.internal.ClientSetup.ResumableClientSetup
 
KeepAliveHandler - Interface in io.rsocket.keepalive
 
KeepAliveHandler.DefaultKeepAliveHandler - Class in io.rsocket.keepalive
 
KeepAliveHandler.ResumableKeepAliveHandler - Class in io.rsocket.keepalive
 
keepAliveInterval() - Method in class io.rsocket.ConnectionSetupPayload
 
keepAliveInterval(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
keepAliveMaxLifetime() - Method in class io.rsocket.ConnectionSetupPayload
 
keepAliveMaxLifetime(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
keepAliveMissedAcks(int) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
KeepAliveSupport - Class in io.rsocket.keepalive
 
KeepAliveSupport.ClientKeepAliveSupport - Class in io.rsocket.keepalive
 
KeepAliveSupport.KeepAlive - Class in io.rsocket.keepalive
 
KeepAliveSupport.ServerKeepAliveSupport - Class in io.rsocket.keepalive
 
keepAliveTickPeriod(Duration) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
keepRunning() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue.ExitCondition
 
keySet() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
keyToString(int) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
Helper method called by SynchronizedIntObjectHashMap.toString() in order to convert a single map key into a string.

L

LAST_POSITION_MASK - Static variable in class io.rsocket.frame.KeepAliveFrameFlyweight
 
lastPosition(ByteBuf) - Static method in class io.rsocket.frame.KeepAliveFrameFlyweight
 
lastReceivedClientPos(ByteBuf) - Static method in class io.rsocket.frame.ResumeOkFrameFlyweight
 
lastReceivedServerPos(ByteBuf) - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
Lease - Interface in io.rsocket.lease
A contract for RSocket lease, which is sent by a request acceptor and is time bound.
lease(Supplier<Leases<? extends LeaseStats>>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
lease() - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
lease(Supplier<Leases<?>>) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
lease() - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
leaseError() - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
leaseError() - Method in interface io.rsocket.lease.RequesterLeaseHandler
 
leaseError() - Method in class io.rsocket.lease.ResponderLeaseHandler.Impl
 
leaseError() - Method in interface io.rsocket.lease.ResponderLeaseHandler
 
LeaseFrameFlyweight - Class in io.rsocket.frame
 
LeaseFrameFlyweight() - Constructor for class io.rsocket.frame.LeaseFrameFlyweight
 
LeaseImpl - Class in io.rsocket.lease
 
Leases<T extends LeaseStats> - Class in io.rsocket.lease
 
Leases() - Constructor for class io.rsocket.lease.Leases
 
LeaseStats - Interface in io.rsocket.lease
 
LeaseStats.EventType - Enum in io.rsocket.lease
 
length(ByteBuf) - Static method in class io.rsocket.frame.FrameLengthFlyweight
 
LimitableRequestPublisher<T> - Class in io.rsocket.internal
 
loadServices() - Static method in interface io.rsocket.uri.UriHandler
Load all registered instances of UriHandler.
lpElement(E[], long) - Static method in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
A plain load (no ordering/fences) of an element from a given offset.
lvConsumerIndex() - Method in interface io.rsocket.internal.jctools.queues.IndexedQueueSizeUtil.IndexedQueue
 
lvElement(E[], long) - Static method in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
A volatile load (load + LoadLoad barrier) of an element from a given offset.
lvProducerIndex() - Method in interface io.rsocket.internal.jctools.queues.IndexedQueueSizeUtil.IndexedQueue
 

M

major(int) - Static method in class io.rsocket.frame.VersionFlyweight
 
MAX_POW2 - Static variable in class io.rsocket.internal.jctools.util.Pow2
 
MEDIUM_BYTES - Static variable in class io.rsocket.util.NumberUtils
The size of a medium in bytes.
MessagePassingQueue<T> - Interface in io.rsocket.internal.jctools.queues
 
MessagePassingQueue.Consumer<T> - Interface in io.rsocket.internal.jctools.queues
 
MessagePassingQueue.ExitCondition - Interface in io.rsocket.internal.jctools.queues
 
MessagePassingQueue.Supplier<T> - Interface in io.rsocket.internal.jctools.queues
 
MessagePassingQueue.WaitStrategy - Interface in io.rsocket.internal.jctools.queues
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.ExtensionFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.LeaseFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.MetadataPushFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.PayloadFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.RequestChannelFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.RequestFireAndForgetFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.RequestResponseFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.RequestStreamFrameFlyweight
 
metadata(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
metadata() - Method in interface io.rsocket.Payload
Returns the Payloads' metadata without slicing if possible.
metadata() - Method in class io.rsocket.util.ByteBufPayload
 
metadata() - Method in class io.rsocket.util.DefaultPayload
 
metadata() - Method in class io.rsocket.util.EmptyPayload
 
metadataMimeType() - Method in class io.rsocket.ConnectionSetupPayload
 
metadataMimeType(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
metadataMimeType(String) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
metadataPush(Payload) - Method in class io.rsocket.AbstractRSocket
 
metadataPush(Payload) - Method in interface io.rsocket.RSocket
Metadata-Push interaction model of RSocket.
metadataPush(Payload) - Method in class io.rsocket.util.MultiSubscriberRSocket
 
metadataPush(Payload) - Method in class io.rsocket.util.RSocketProxy
 
MetadataPushFrameFlyweight - Class in io.rsocket.frame
 
MetadataPushFrameFlyweight() - Constructor for class io.rsocket.frame.MetadataPushFrameFlyweight
 
mimeType(String, String) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
minor(int) - Static method in class io.rsocket.frame.VersionFlyweight
 
MissingLeaseException - Exception in io.rsocket.exceptions
 
MissingLeaseException(Lease, String) - Constructor for exception io.rsocket.exceptions.MissingLeaseException
 
MissingLeaseException(String) - Constructor for exception io.rsocket.exceptions.MissingLeaseException
 
MpscUnboundedArrayQueue<E> - Class in io.rsocket.internal.jctools.queues
An MPSC array queue which starts at initialCapacity and grows indefinitely in linked chunks of the initial size.
MpscUnboundedArrayQueue(int) - Constructor for class io.rsocket.internal.jctools.queues.MpscUnboundedArrayQueue
 
MultiSubscriberRSocket - Class in io.rsocket.util
 
MultiSubscriberRSocket(RSocket) - Constructor for class io.rsocket.util.MultiSubscriberRSocket
 

N

name() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
nativeFrameType(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
faster version of FrameHeaderFlyweight.frameType(ByteBuf) which does not replace PAYLOAD with synthetic type
next(int, int) - Static method in class io.rsocket.internal.BitUtil
Cycles indices of an array one at a time in a forward fashion
None - Static variable in interface io.rsocket.lease.RequesterLeaseHandler
 
None - Static variable in interface io.rsocket.lease.ResponderLeaseHandler
 
now() - Static method in class io.rsocket.util.Clock
 
NumberUtils - Class in io.rsocket.util
 
numRequests(ByteBuf) - Static method in class io.rsocket.frame.LeaseFrameFlyweight
 

O

of(ByteBuf, ByteBuf) - Static method in class io.rsocket.buffer.TupleByteBuf
 
of(ByteBufAllocator, ByteBuf, ByteBuf) - Static method in class io.rsocket.buffer.TupleByteBuf
 
of(ByteBuf, ByteBuf, ByteBuf) - Static method in class io.rsocket.buffer.TupleByteBuf
 
of(ByteBufAllocator, ByteBuf, ByteBuf, ByteBuf) - Static method in class io.rsocket.buffer.TupleByteBuf
 
offer(E) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
offer(T) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
OnceConsumer<T> - Class in io.rsocket.util
 
OnceConsumer() - Constructor for class io.rsocket.util.OnceConsumer
 
onClose() - Method in class io.rsocket.AbstractRSocket
 
onClose() - Method in interface io.rsocket.Closeable
Returns a Publisher that completes when this RSocket is closed.
onClose() - Method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
onClose() - Method in class io.rsocket.internal.BaseDuplexConnection
 
onClose() - Method in class io.rsocket.internal.ClientServerInputMultiplexer
 
onClose() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
onClose() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
onClose() - Method in interface io.rsocket.resume.RSocketSession
 
onClose() - Method in class io.rsocket.util.DuplexConnectionProxy
 
onClose() - Method in class io.rsocket.util.RSocketProxy
 
onComplete() - Method in class io.rsocket.internal.UnboundedProcessor
 
onComplete() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
onDisconnect(Runnable) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
onError(Throwable) - Method in class io.rsocket.internal.UnboundedProcessor
 
onError(Throwable) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
onEvent(LeaseStats.EventType) - Method in interface io.rsocket.lease.LeaseStats
 
onImpliedPosition(long) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
onImpliedPosition(long) - Method in interface io.rsocket.resume.ResumeStateHolder
 
onNext(T) - Method in class io.rsocket.internal.UnboundedProcessor
 
onNext(O) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
onResume(Runnable) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
onSendKeepAliveFrame(Consumer<ByteBuf>) - Method in class io.rsocket.keepalive.KeepAliveSupport
 
onSubscribe(Subscription) - Method in class io.rsocket.internal.UnboundedProcessor
 
onSubscribe(Subscription) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
onTimeout(Consumer<KeepAliveSupport.KeepAlive>) - Method in class io.rsocket.keepalive.KeepAliveSupport
 

P

parents() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
Payload - Interface in io.rsocket
Payload of a Frame .
PayloadDecoder - Interface in io.rsocket.frame.decoder
 
PayloadFrameFlyweight - Class in io.rsocket.frame
 
peek() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
peek() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
peek() - Method in class io.rsocket.internal.UnboundedProcessor
 
peek() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
PeriodicResumeStrategy - Class in io.rsocket.resume
 
PeriodicResumeStrategy(Duration) - Constructor for class io.rsocket.resume.PeriodicResumeStrategy
 
PluginRegistry - Class in io.rsocket.plugins
 
PluginRegistry() - Constructor for class io.rsocket.plugins.PluginRegistry
 
PluginRegistry(PluginRegistry) - Constructor for class io.rsocket.plugins.PluginRegistry
 
Plugins - Class in io.rsocket.plugins
JVM wide plugins for RSocket
poll() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
poll() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
poll() - Method in class io.rsocket.internal.UnboundedProcessor
 
PortableJvmInfo - Interface in io.rsocket.internal.jctools.util
JVM Information that is standard and available on all JVMs (i.e.
position() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
Pow2 - Class in io.rsocket.internal.jctools.util
Power of 2 utility functions.
Pow2() - Constructor for class io.rsocket.internal.jctools.util.Pow2
 
previous(int, int) - Static method in class io.rsocket.internal.BitUtil
Cycles indices of an array one at a time in a backwards fashion
put(int, V) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
put(Integer, V) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
putAll(Map<? extends Integer, ? extends V>) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 

Q

QueueProgressIndicators - Interface in io.rsocket.internal.jctools.queues
This interface is provided for monitoring purposes only and is only available on queues where it is easy to provide it.

R

RangeUtil - Class in io.rsocket.internal.jctools.util
 
RangeUtil() - Constructor for class io.rsocket.internal.jctools.util.RangeUtil
 
receive() - Method in interface io.rsocket.DuplexConnection
Returns a stream of all Frames received on this connection.
receive() - Method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
receive(ByteBuf) - Method in interface io.rsocket.keepalive.KeepAliveFramesAcceptor
 
receive(ByteBuf) - Method in class io.rsocket.keepalive.KeepAliveSupport
 
receive(ByteBuf) - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
receive(ByteBuf) - Method in interface io.rsocket.lease.RequesterLeaseHandler
 
receive() - Method in class io.rsocket.resume.ResumableDuplexConnection
 
receive() - Static method in class io.rsocket.RSocketFactory
Creates a factory that receives server connections from client RSockets.
receive() - Method in class io.rsocket.util.DuplexConnectionProxy
 
receiver(Consumer<Flux<Lease>>) - Method in class io.rsocket.lease.Leases
 
receiver() - Method in class io.rsocket.lease.Leases
 
RECOMENDED_OFFER_BATCH - Static variable in interface io.rsocket.internal.jctools.util.PortableJvmInfo
 
RECOMENDED_POLL_BATCH - Static variable in interface io.rsocket.internal.jctools.util.PortableJvmInfo
 
reconnect(DuplexConnection) - Method in class io.rsocket.resume.ClientRSocketSession
 
reconnect(DuplexConnection) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
reconnect(DuplexConnection) - Method in interface io.rsocket.resume.RSocketSession
 
reconnect(DuplexConnection) - Method in class io.rsocket.resume.ServerRSocketSession
 
RecyclerFactory - Class in io.rsocket.util
A factory for creating Recyclers.
RecyclerFactory() - Constructor for class io.rsocket.util.RecyclerFactory
 
REF_ARRAY_BASE - Static variable in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
 
REF_ELEMENT_SHIFT - Static variable in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
 
refCnt() - Method in class io.rsocket.util.DefaultPayload
 
refCnt() - Method in class io.rsocket.util.EmptyPayload
 
REJECTED - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
REJECTED - Static variable in class io.rsocket.frame.ErrorType
Despite being a valid request, the Responder decided to reject it.
REJECTED_RESUME - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
REJECTED_RESUME - Static variable in class io.rsocket.frame.ErrorType
The server rejected the resume, it can specify the reason in the payload.
REJECTED_SETUP - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
REJECTED_SETUP - Static variable in class io.rsocket.frame.ErrorType
The server rejected the setup, it can specify the reason in the payload.
RejectedException - Exception in io.rsocket.exceptions
Despite being a valid request, the Responder decided to reject it.
RejectedException(String) - Constructor for exception io.rsocket.exceptions.RejectedException
Constructs a new exception with the specified message.
RejectedException(String, Throwable) - Constructor for exception io.rsocket.exceptions.RejectedException
Constructs a new exception with the specified message and cause.
RejectedResumeException - Exception in io.rsocket.exceptions
The server rejected the resume, it can specify the reason in the payload.
RejectedResumeException(String) - Constructor for exception io.rsocket.exceptions.RejectedResumeException
Constructs a new exception with the specified message.
RejectedResumeException(String, Throwable) - Constructor for exception io.rsocket.exceptions.RejectedResumeException
Constructs a new exception with the specified message and cause.
RejectedSetupException - Exception in io.rsocket.exceptions
The server rejected the setup, it can specify the reason in the payload.
RejectedSetupException(String) - Constructor for exception io.rsocket.exceptions.RejectedSetupException
Constructs a new exception with the specified message.
RejectedSetupException(String, Throwable) - Constructor for exception io.rsocket.exceptions.RejectedSetupException
Constructs a new exception with the specified message and cause.
relaxedOffer(E) - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
relaxedOffer(T) - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
relaxedPeek() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
relaxedPeek() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
relaxedPoll() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
relaxedPoll() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
release() - Method in class io.rsocket.util.DefaultPayload
 
release(int) - Method in class io.rsocket.util.DefaultPayload
 
release() - Method in class io.rsocket.util.EmptyPayload
 
release(int) - Method in class io.rsocket.util.EmptyPayload
 
releaseFrames(long) - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
releaseFrames(long) - Method in interface io.rsocket.resume.ResumableFramesStore
Release frames from tail of the store up to remote implied position
remove(int) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
remove(Object) - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
removeIf(List<T>, Predicate<T>) - Static method in class io.rsocket.internal.CollectionUtil
Remove element from a list if it matches a predicate.
request(long) - Method in class io.rsocket.internal.LimitableRequestPublisher
 
request(long) - Method in class io.rsocket.internal.UnboundedProcessor
 
request(long) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
requestChannel(Publisher<Payload>) - Method in class io.rsocket.AbstractRSocket
 
requestChannel(Payload, Publisher<Payload>) - Method in interface io.rsocket.ResponderRSocket
Implement this method to peak at the first payload of the incoming request stream without having to subscribe to Publish<Payload> payloads
requestChannel(Publisher<Payload>) - Method in interface io.rsocket.RSocket
Request-Channel interaction model of RSocket.
requestChannel(Publisher<Payload>) - Method in class io.rsocket.util.MultiSubscriberRSocket
 
requestChannel(Publisher<Payload>) - Method in class io.rsocket.util.RSocketProxy
 
RequestChannelFrameFlyweight - Class in io.rsocket.frame
 
RequesterLeaseHandler - Interface in io.rsocket.lease
 
RequesterLeaseHandler.Impl - Class in io.rsocket.lease
 
RequestFireAndForgetFrameFlyweight - Class in io.rsocket.frame
 
requestFusion(int) - Method in class io.rsocket.internal.UnboundedProcessor
 
requestN(ByteBuf) - Static method in class io.rsocket.frame.RequestNFrameFlyweight
 
RequestNFrameFlyweight - Class in io.rsocket.frame
 
requestResponse(Payload) - Method in class io.rsocket.AbstractRSocket
 
requestResponse(Payload) - Method in interface io.rsocket.RSocket
Request-Response interaction model of RSocket.
requestResponse(Payload) - Method in class io.rsocket.util.MultiSubscriberRSocket
 
requestResponse(Payload) - Method in class io.rsocket.util.RSocketProxy
 
RequestResponseFrameFlyweight - Class in io.rsocket.frame
 
requestStream(Payload) - Method in class io.rsocket.AbstractRSocket
 
requestStream(Payload) - Method in interface io.rsocket.RSocket
Request-Stream interaction model of RSocket.
requestStream(Payload) - Method in class io.rsocket.util.MultiSubscriberRSocket
 
requestStream(Payload) - Method in class io.rsocket.util.RSocketProxy
 
RequestStreamFrameFlyweight - Class in io.rsocket.frame
 
requireNonNegative(int, String) - Static method in class io.rsocket.util.NumberUtils
Requires that an int is greater than or equal to zero.
requirePositive(long, String) - Static method in class io.rsocket.util.NumberUtils
Requires that a long is greater than zero.
requirePositive(int, String) - Static method in class io.rsocket.util.NumberUtils
Requires that an int is greater than zero.
requireUnsignedByte(int) - Static method in class io.rsocket.util.NumberUtils
Requires that an int can be represented as an unsigned byte.
requireUnsignedMedium(int) - Static method in class io.rsocket.util.NumberUtils
Requires that an int can be represented as an unsigned medium.
requireUnsignedShort(int) - Static method in class io.rsocket.util.NumberUtils
Requires that an int can be represented as an unsigned short.
RESERVED - Static variable in class io.rsocket.frame.ErrorType
Reserved.
RESERVED_FOR_EXTENSION - Static variable in class io.rsocket.frame.ErrorType
Reserved for Extension Use.
ReservedMimeTypeEntry(ByteBuf, int) - Constructor for class io.rsocket.metadata.CompositeMetadata.ReservedMimeTypeEntry
 
ResponderLeaseHandler - Interface in io.rsocket.lease
 
ResponderLeaseHandler.Impl<T extends LeaseStats> - Class in io.rsocket.lease
 
ResponderRSocket - Interface in io.rsocket
Extends the RSocket that allows an implementer to peek at the first request payload of a channel.
respondFlag(ByteBuf) - Static method in class io.rsocket.frame.KeepAliveFrameFlyweight
 
ResumableClientSetup(ByteBufAllocator, DuplexConnection, Mono<DuplexConnection>, ByteBuf, ResumableFramesStore, Duration, Duration, Supplier<ResumeStrategy>, boolean) - Constructor for class io.rsocket.internal.ClientSetup.ResumableClientSetup
 
resumableConnection() - Method in class io.rsocket.resume.ClientRSocketSession
 
resumableConnection() - Method in interface io.rsocket.resume.RSocketSession
 
resumableConnection() - Method in class io.rsocket.resume.ServerRSocketSession
 
ResumableDuplexConnection - Class in io.rsocket.resume
 
ResumableDuplexConnection(String, DuplexConnection, ResumableFramesStore, Duration, boolean) - Constructor for class io.rsocket.resume.ResumableDuplexConnection
 
resumableFrameReceived(ByteBuf) - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
resumableFrameReceived(ByteBuf) - Method in interface io.rsocket.resume.ResumableFramesStore
Received resumable frame as defined by RSocket protocol.
ResumableFramesStore - Interface in io.rsocket.resume
Store for resumable frames
ResumableKeepAliveHandler(ResumableDuplexConnection) - Constructor for class io.rsocket.keepalive.KeepAliveHandler.ResumableKeepAliveHandler
 
ResumableServerSetup(ByteBufAllocator, SessionManager, Duration, Duration, Function<? super ByteBuf, ? extends ResumableFramesStore>, boolean) - Constructor for class io.rsocket.internal.ServerSetup.ResumableServerSetup
 
resume(long, long, Function<Mono<Long>, Mono<Void>>) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
resume() - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resume() - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
resumeCleanupOnKeepAlive() - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeCleanupOnKeepAlive() - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
resumeEnabled(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
ResumeFrameFlyweight - Class in io.rsocket.frame
 
ResumeFrameFlyweight() - Constructor for class io.rsocket.frame.ResumeFrameFlyweight
 
ResumeOkFrameFlyweight - Class in io.rsocket.frame
 
ResumeOkFrameFlyweight() - Constructor for class io.rsocket.frame.ResumeOkFrameFlyweight
 
resumeSessionDuration(Duration) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeSessionDuration(Duration) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
resumeState(ResumeStateHolder) - Method in class io.rsocket.keepalive.KeepAliveSupport
 
ResumeStateHolder - Interface in io.rsocket.resume
 
resumeStore(Function<? super ByteBuf, ? extends ResumableFramesStore>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeStore(Function<? super ByteBuf, ? extends ResumableFramesStore>) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
ResumeStrategy - Interface in io.rsocket.resume
 
resumeStrategy(Supplier<ResumeStrategy>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeStream() - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
resumeStream() - Method in interface io.rsocket.resume.ResumableFramesStore
 
resumeStreamTimeout(Duration) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeStreamTimeout(Duration) - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
resumeToken(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
resumeToken() - Method in class io.rsocket.internal.ClientSetup.DefaultClientSetup
 
resumeToken() - Method in class io.rsocket.internal.ClientSetup.ResumableClientSetup
 
resumeToken() - Method in interface io.rsocket.internal.ClientSetup
 
resumeToken() - Method in class io.rsocket.resume.ClientResume
 
resumeToken(ByteBuf) - Method in class io.rsocket.resume.ClientRSocketSession
 
resumeToken(Supplier<ByteBuf>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
resumeTokenLength(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
resumeWith(ByteBuf) - Method in class io.rsocket.resume.ClientRSocketSession
 
resumeWith(ByteBuf) - Method in interface io.rsocket.resume.RSocketSession
 
resumeWith(ByteBuf) - Method in class io.rsocket.resume.ServerRSocketSession
 
retain() - Method in class io.rsocket.ConnectionSetupPayload
 
retain(int) - Method in class io.rsocket.ConnectionSetupPayload
 
retain() - Method in interface io.rsocket.Payload
Increases the reference count by 1.
retain(int) - Method in interface io.rsocket.Payload
Increases the reference count by the specified increment.
retain() - Method in class io.rsocket.util.ByteBufPayload
 
retain(int) - Method in class io.rsocket.util.ByteBufPayload
 
retain() - Method in class io.rsocket.util.DefaultPayload
 
retain(int) - Method in class io.rsocket.util.DefaultPayload
 
retain() - Method in class io.rsocket.util.EmptyPayload
 
retain(int) - Method in class io.rsocket.util.EmptyPayload
 
Retryable - Interface in io.rsocket.exceptions
Indicates that an exception is retryable.
roundToPowerOfTwo(int) - Static method in class io.rsocket.internal.jctools.util.Pow2
 
RSocket - Interface in io.rsocket
A contract providing different interaction models for RSocket protocol.
RSocketException - Exception in io.rsocket.exceptions
The root of the RSocket exception hierarchy.
RSocketException(String) - Constructor for exception io.rsocket.exceptions.RSocketException
Constructs a new exception with the specified message.
RSocketException(String, Throwable) - Constructor for exception io.rsocket.exceptions.RSocketException
Constructs a new exception with the specified message and cause.
RSocketFactory - Class in io.rsocket
Factory for creating RSocket clients and servers.
RSocketFactory() - Constructor for class io.rsocket.RSocketFactory
 
RSocketFactory.ClientRSocketFactory - Class in io.rsocket
 
RSocketFactory.ClientTransportAcceptor - Interface in io.rsocket
 
RSocketFactory.ServerRSocketFactory - Class in io.rsocket
 
RSocketFactory.ServerTransportAcceptor - Interface in io.rsocket
 
RSocketFactory.Start<T extends Closeable> - Interface in io.rsocket
 
RSocketInterceptor - Interface in io.rsocket.plugins
 
RSocketProxy - Class in io.rsocket.util
Wrapper/Proxy for a RSocket.
RSocketProxy(RSocket) - Constructor for class io.rsocket.util.RSocketProxy
 
RSocketSession<T> - Interface in io.rsocket.resume
 

S

save(ServerRSocketSession) - Method in class io.rsocket.resume.SessionManager
 
saveFrames(Flux<ByteBuf>) - Method in class io.rsocket.resume.InMemoryResumableFramesStore
 
saveFrames(Flux<ByteBuf>) - Method in interface io.rsocket.resume.ResumableFramesStore
Save resumable frames for potential resumption
scan(Scannable.Attr<T>) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
scanOrDefault(Scannable.Attr<T>, T) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
scanUnsafe(Scannable.Attr) - Method in class io.rsocket.internal.UnboundedProcessor
 
scanUnsafe(Scannable.Attr) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
send(Publisher<ByteBuf>) - Method in interface io.rsocket.DuplexConnection
Sends the source of Frames on this connection and returns the Publisher representing the result of this send.
send(Publisher<ByteBuf>) - Method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
send(Consumer<ByteBuf>) - Method in class io.rsocket.lease.ResponderLeaseHandler.Impl
 
send(Consumer<ByteBuf>) - Method in interface io.rsocket.lease.ResponderLeaseHandler
 
send(Publisher<ByteBuf>) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
send(Publisher<ByteBuf>) - Method in class io.rsocket.util.DuplexConnectionProxy
 
sender(Function<Optional<T>, Flux<Lease>>) - Method in class io.rsocket.lease.Leases
 
sender() - Method in class io.rsocket.lease.Leases
 
sendError(ByteBufAllocator, ClientServerInputMultiplexer, Exception) - Static method in class io.rsocket.util.ConnectionUtils
 
sendOne(ByteBuf) - Method in interface io.rsocket.DuplexConnection
Sends a single Frame on this connection and returns the Publisher representing the result of this send.
sendOne(ByteBuf) - Method in class io.rsocket.fragmentation.FragmentationDuplexConnection
 
sendOne(ByteBuf) - Method in class io.rsocket.resume.ResumableDuplexConnection
 
serverForUri(String) - Static method in class io.rsocket.uri.UriTransportRegistry
 
ServerKeepAliveSupport(ByteBufAllocator, int, int) - Constructor for class io.rsocket.keepalive.KeepAliveSupport.ServerKeepAliveSupport
 
ServerRSocketSession - Class in io.rsocket.resume
 
ServerRSocketSession(DuplexConnection, ByteBufAllocator, Duration, Duration, Function<? super ByteBuf, ? extends ResumableFramesStore>, ByteBuf, boolean) - Constructor for class io.rsocket.resume.ServerRSocketSession
 
ServerSetup - Interface in io.rsocket.internal
 
ServerSetup.DefaultServerSetup - Class in io.rsocket.internal
 
ServerSetup.ResumableServerSetup - Class in io.rsocket.internal
 
ServerTransport<T extends Closeable> - Interface in io.rsocket.transport
A server contract for writing transports of RSocket.
ServerTransport.ConnectionAcceptor - Interface in io.rsocket.transport
A contract to accept a new DuplexConnection.
sessionDuration() - Method in class io.rsocket.resume.ClientResume
 
SessionManager - Class in io.rsocket.resume
 
SessionManager() - Constructor for class io.rsocket.resume.SessionManager
 
setTransportHeaders(Supplier<Map<String, String>>) - Method in interface io.rsocket.transport.TransportHeaderAware
Sets the transport headers
SetupException - Exception in io.rsocket.exceptions
The root of the setup exception hierarchy.
SetupException(String) - Constructor for exception io.rsocket.exceptions.SetupException
Constructs a new exception with the specified message.
SetupException(String, Throwable) - Constructor for exception io.rsocket.exceptions.SetupException
Constructs a new exception with the specified message and cause.
SetupFrameFlyweight - Class in io.rsocket.frame
 
SetupFrameFlyweight() - Constructor for class io.rsocket.frame.SetupFrameFlyweight
 
setupPayload(Payload) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
singleSubscriberRequester() - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
singleSubscriberRequester() - Method in class io.rsocket.RSocketFactory.ServerRSocketFactory
 
size() - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
size() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
size(IndexedQueueSizeUtil.IndexedQueue) - Static method in class io.rsocket.internal.jctools.queues.IndexedQueueSizeUtil
 
size() - Method in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
size() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
size() - Method in class io.rsocket.internal.UnboundedProcessor
 
SIZE_OF_BOOLEAN - Static variable in class io.rsocket.internal.BitUtil
Size of a boolean in bytes
SIZE_OF_BYTE - Static variable in class io.rsocket.internal.BitUtil
Size of a byte in bytes
SIZE_OF_CHAR - Static variable in class io.rsocket.internal.BitUtil
Size of a char in bytes
SIZE_OF_DOUBLE - Static variable in class io.rsocket.internal.BitUtil
Size of a double in bytes
SIZE_OF_FLOAT - Static variable in class io.rsocket.internal.BitUtil
Size of a float in bytes
SIZE_OF_INT - Static variable in class io.rsocket.internal.BitUtil
Size of an int in bytes
SIZE_OF_LONG - Static variable in class io.rsocket.internal.BitUtil
Size of a long in bytes
SIZE_OF_SHORT - Static variable in class io.rsocket.internal.BitUtil
Size of a short in bytes
sliceData() - Method in interface io.rsocket.Payload
Returns the Payload data.
sliceData() - Method in class io.rsocket.util.ByteBufPayload
 
sliceData() - Method in class io.rsocket.util.DefaultPayload
 
sliceData() - Method in class io.rsocket.util.EmptyPayload
 
sliceMetadata() - Method in interface io.rsocket.Payload
Returns a slice Payload metadata.
sliceMetadata() - Method in class io.rsocket.util.ByteBufPayload
 
sliceMetadata() - Method in class io.rsocket.util.DefaultPayload
 
sliceMetadata() - Method in class io.rsocket.util.EmptyPayload
 
SocketAcceptor - Interface in io.rsocket
RSocket is a full duplex protocol where a client and server are identical in terms of both having the capability to initiate requests to their peer.
soElement(E[], long, E) - Static method in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
An ordered store(store + StoreStore barrier) of an element to a given offset
source - Variable in class io.rsocket.util.RSocketProxy
 
spElement(E[], long, E) - Static method in class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
A plain store (no ordering/fences) of an element to a given offset
start(KeepAliveSupport, Consumer<ByteBuf>, Consumer<KeepAliveSupport.KeepAlive>) - Method in class io.rsocket.keepalive.KeepAliveHandler.DefaultKeepAliveHandler
 
start(KeepAliveSupport, Consumer<ByteBuf>, Consumer<KeepAliveSupport.KeepAlive>) - Method in class io.rsocket.keepalive.KeepAliveHandler.ResumableKeepAliveHandler
 
start(KeepAliveSupport, Consumer<ByteBuf>, Consumer<KeepAliveSupport.KeepAlive>) - Method in interface io.rsocket.keepalive.KeepAliveHandler
 
start() - Method in class io.rsocket.keepalive.KeepAliveSupport
 
start() - Method in interface io.rsocket.RSocketFactory.Start
 
start(ServerTransport.ConnectionAcceptor, int) - Method in interface io.rsocket.transport.ServerTransport
Starts this server.
stats(T) - Method in class io.rsocket.lease.Leases
 
stats() - Method in class io.rsocket.lease.Leases
 
stepName() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
steps() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
stop() - Method in class io.rsocket.keepalive.KeepAliveSupport
 
stream() - Method in class io.rsocket.metadata.CompositeMetadata
Turn this CompositeMetadata into a sequential Stream.
streamId(ByteBuf) - Static method in class io.rsocket.frame.FrameHeaderFlyweight
 
subscribe(CoreSubscriber<? super T>) - Method in class io.rsocket.internal.LimitableRequestPublisher
 
subscribe(CoreSubscriber<? super R>) - Method in class io.rsocket.internal.SwitchTransformFlux
Deprecated.
 
subscribe(CoreSubscriber<? super T>) - Method in class io.rsocket.internal.UnboundedProcessor
 
subscribe(CoreSubscriber<? super O>) - Method in class io.rsocket.internal.UnicastMonoProcessor
 
sum(List<V>, ToIntFunction<V>) - Static method in class io.rsocket.internal.CollectionUtil
Garbage free sum function.
SUPPORTS_GET_AND_SET - Static variable in class io.rsocket.internal.jctools.util.UnsafeAccess
 
SupportsIterator - Interface in io.rsocket.internal.jctools.queues
Tagging interface to help testing
SwitchTransformFlux<T,R> - Class in io.rsocket.internal
Deprecated.
SwitchTransformFlux(Publisher<? extends T>, BiFunction<T, Flux<T>, Publisher<? extends R>>) - Constructor for class io.rsocket.internal.SwitchTransformFlux
Deprecated.
 
SynchronizedIntObjectHashMap<V> - Class in io.rsocket.internal
A hash map implementation of IntObjectMap that uses open addressing for keys.
SynchronizedIntObjectHashMap() - Constructor for class io.rsocket.internal.SynchronizedIntObjectHashMap
 
SynchronizedIntObjectHashMap(int) - Constructor for class io.rsocket.internal.SynchronizedIntObjectHashMap
 
SynchronizedIntObjectHashMap(int, float) - Constructor for class io.rsocket.internal.SynchronizedIntObjectHashMap
 

T

tags() - Method in class io.rsocket.internal.UnicastMonoProcessor
 
toConnectionAcceptor() - Method in interface io.rsocket.RSocketFactory.ServerTransportAcceptor
 
toHex(byte[], int, int) - Static method in class io.rsocket.internal.BitUtil
Generate a string that is the hex representation of a given byte array.
toHex(byte[]) - Static method in class io.rsocket.internal.BitUtil
Generate a string that is the hex representation of a given byte array.
toHexByteArray(byte[]) - Static method in class io.rsocket.internal.BitUtil
Generate a byte array that is a hex representation of a given byte array.
toHexByteArray(byte[], int, int) - Static method in class io.rsocket.internal.BitUtil
Generate a byte array that is a hex representation of a given byte array.
token(ByteBuf) - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
token() - Method in class io.rsocket.resume.ClientRSocketSession
 
token() - Method in interface io.rsocket.resume.RSocketSession
 
token() - Method in class io.rsocket.resume.ServerRSocketSession
 
toString(ByteBuf) - Static method in class io.rsocket.frame.FrameUtil
 
toString(int) - Static method in class io.rsocket.frame.VersionFlyweight
 
toString() - Method in class io.rsocket.internal.jctools.queues.BaseMpscLinkedArrayQueue
 
toString() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
toString() - Method in class io.rsocket.lease.LeaseImpl
 
toString() - Method in enum io.rsocket.metadata.WellKnownMimeType
 
toString() - Method in class io.rsocket.resume.ExponentialBackoffResumeStrategy
 
toString() - Method in class io.rsocket.resume.PeriodicResumeStrategy
 
touch() - Method in class io.rsocket.ConnectionSetupPayload
 
touch(Object) - Method in class io.rsocket.ConnectionSetupPayload
 
touch() - Method in interface io.rsocket.Payload
Records the current access location of this object for debugging purposes.
touch(Object) - Method in interface io.rsocket.Payload
Records the current access location of this object with an additional arbitrary information for debugging purposes.
touch() - Method in class io.rsocket.util.ByteBufPayload
 
touch(Object) - Method in class io.rsocket.util.ByteBufPayload
 
touch() - Method in class io.rsocket.util.DefaultPayload
 
touch(Object) - Method in class io.rsocket.util.DefaultPayload
 
touch() - Method in class io.rsocket.util.EmptyPayload
 
touch(Object) - Method in class io.rsocket.util.EmptyPayload
 
transport(Supplier<ClientTransport>) - Method in class io.rsocket.RSocketFactory.ClientRSocketFactory
 
transport(Supplier<ClientTransport>) - Method in interface io.rsocket.RSocketFactory.ClientTransportAcceptor
 
transport(ClientTransport) - Method in interface io.rsocket.RSocketFactory.ClientTransportAcceptor
 
transport(Supplier<ServerTransport<T>>) - Method in interface io.rsocket.RSocketFactory.ServerTransportAcceptor
 
transport(ServerTransport<T>) - Method in interface io.rsocket.RSocketFactory.ServerTransportAcceptor
 
Transport - Interface in io.rsocket.transport
 
TransportHeaderAware - Interface in io.rsocket.transport
Extension interface to support Transports with headers at the transport layer, e.g.
ttl(ByteBuf) - Static method in class io.rsocket.frame.LeaseFrameFlyweight
 
TupleByteBuf - Class in io.rsocket.buffer
 

U

UNBOUNDED_CAPACITY - Static variable in interface io.rsocket.internal.jctools.queues.MessagePassingQueue
 
UnboundedProcessor<T> - Class in io.rsocket.internal
A Processor implementation that takes a custom queue and allows only a single subscriber.
UnboundedProcessor() - Constructor for class io.rsocket.internal.UnboundedProcessor
 
UnicastMonoProcessor<O> - Class in io.rsocket.internal
 
unit() - Static method in class io.rsocket.util.Clock
 
UNSAFE - Static variable in class io.rsocket.internal.jctools.util.UnsafeAccess
 
UnsafeAccess - Class in io.rsocket.internal.jctools.util
Why should we resort to using Unsafe?
To construct class fields which allow volatile/ordered/plain access: This requirement is covered by AtomicReferenceFieldUpdater and similar but their performance is arguably worse than the DIY approach (depending on JVM version) while Unsafe intrinsification is a far lesser challenge for JIT compilers.
UnsafeAccess() - Constructor for class io.rsocket.internal.jctools.util.UnsafeAccess
 
UnsafeRefArrayAccess - Class in io.rsocket.internal.jctools.util
A concurrent access enabling class used by circular array based queues this class exposes an offset computation method along with differently memory fenced load/store methods into the underlying array.
UnsafeRefArrayAccess() - Constructor for class io.rsocket.internal.jctools.util.UnsafeRefArrayAccess
 
UNSUPPORTED_SETUP - Static variable in class io.rsocket.frame.ErrorFrameFlyweight
 
UNSUPPORTED_SETUP - Static variable in class io.rsocket.frame.ErrorType
Some (or all) of the parameters specified by the client are unsupported by the server.
UnsupportedSetupException - Exception in io.rsocket.exceptions
Some (or all) of the parameters specified by the client are unsupported by the server.
UnsupportedSetupException(String) - Constructor for exception io.rsocket.exceptions.UnsupportedSetupException
Constructs a new exception with the specified message.
UnsupportedSetupException(String, Throwable) - Constructor for exception io.rsocket.exceptions.UnsupportedSetupException
Constructs a new exception with the specified message and cause.
UriHandler - Interface in io.rsocket.uri
UriTransportRegistry - Class in io.rsocket.uri
Registry for looking up transports by URI.
UriTransportRegistry(ServiceLoader<UriHandler>) - Constructor for class io.rsocket.uri.UriTransportRegistry
 
use() - Method in class io.rsocket.lease.LeaseImpl
try use 1 allowed request of Lease
useLease() - Method in class io.rsocket.lease.RequesterLeaseHandler.Impl
 
useLease() - Method in interface io.rsocket.lease.RequesterLeaseHandler
 
useLease() - Method in class io.rsocket.lease.ResponderLeaseHandler.Impl
 
useLease() - Method in interface io.rsocket.lease.ResponderLeaseHandler
 

V

validateLoadFactor(float) - Static method in class io.rsocket.internal.CollectionUtil
Validate that a load factor is in the range of 0.1 to 0.9.
validatePositivePowerOfTwo(int) - Static method in class io.rsocket.internal.CollectionUtil
Validate that a number is a power of two.
valueOf(String) - Static method in enum io.rsocket.frame.FrameType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.rsocket.lease.LeaseStats.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.rsocket.metadata.WellKnownMimeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.rsocket.plugins.DuplexConnectionInterceptor.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.rsocket.frame.FrameType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class io.rsocket.internal.SynchronizedIntObjectHashMap
 
values() - Static method in enum io.rsocket.lease.LeaseStats.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.rsocket.metadata.WellKnownMimeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.rsocket.plugins.DuplexConnectionInterceptor.Type
Returns an array containing the constants of this enum type, in the order they are declared.
version(ByteBuf) - Static method in class io.rsocket.frame.ResumeFrameFlyweight
 
version(ByteBuf) - Static method in class io.rsocket.frame.SetupFrameFlyweight
 
VersionFlyweight - Class in io.rsocket.frame
 
VersionFlyweight() - Constructor for class io.rsocket.frame.VersionFlyweight
 

W

WellKnownMimeType - Enum in io.rsocket.metadata
Enumeration of Well Known Mime Types, as defined in the eponymous extension.
WellKnownMimeTypeEntry(ByteBuf, WellKnownMimeType) - Constructor for class io.rsocket.metadata.CompositeMetadata.WellKnownMimeTypeEntry
 
willClientHonorLease() - Method in class io.rsocket.ConnectionSetupPayload
 
wrap(Publisher<T>, long) - Static method in class io.rsocket.internal.LimitableRequestPublisher
 
wrap(Publisher<T>) - Static method in class io.rsocket.internal.LimitableRequestPublisher
 

Z

ZERO_COPY - Static variable in interface io.rsocket.frame.decoder.PayloadDecoder
 
ZeroCopyPayloadDecoder - Class in io.rsocket.frame.decoder
Frame decoder that decodes a frame to a payload without copying.
ZeroCopyPayloadDecoder() - Constructor for class io.rsocket.frame.decoder.ZeroCopyPayloadDecoder
 
A B C D E F G H I K L M N O P Q R S T U V W Z 
Skip navigation links