Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering conduits.
- AbstractConduit(D) - Constructor for class org.xnio.conduits.AbstractConduit
-
Construct a new instance.
- AbstractConvertingIoFuture<T,
D> - Class in org.xnio -
An
IoFuture
implementation that wraps a different type ofIoFuture
. - AbstractConvertingIoFuture(IoFuture<? extends D>) - Constructor for class org.xnio.AbstractConvertingIoFuture
- AbstractIoFuture<T> - Class in org.xnio
-
An abstract base class for
IoFuture
objects. - AbstractIoFuture() - Constructor for class org.xnio.AbstractIoFuture
-
Construct a new instance.
- AbstractMessageSinkConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering message sink conduits.
- AbstractMessageSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractMessageSinkConduit
-
Construct a new instance.
- AbstractMessageSourceConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering message source conduits.
- AbstractMessageSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractMessageSourceConduit
-
Construct a new instance.
- AbstractSinkConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering output conduits.
- AbstractSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractSinkConduit
-
Construct a new instance.
- AbstractSourceConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering source conduits.
- AbstractSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractSourceConduit
-
Construct a new instance.
- AbstractStreamSinkConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering stream sink conduits.
- AbstractStreamSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractStreamSinkConduit
-
Construct a new instance.
- AbstractStreamSourceConduit<D> - Class in org.xnio.conduits
-
An abstract base class for filtering stream source conduits.
- AbstractStreamSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractStreamSourceConduit
-
Construct a new instance.
- AbstractSynchronizedConduit<D> - Class in org.xnio.conduits
-
An abstract synchronized conduit.
- AbstractSynchronizedConduit(D) - Constructor for class org.xnio.conduits.AbstractSynchronizedConduit
-
Construct a new instance.
- AbstractSynchronizedConduit(D, Object) - Constructor for class org.xnio.conduits.AbstractSynchronizedConduit
-
Construct a new instance.
- AbstractSynchronizedSinkConduit<D> - Class in org.xnio.conduits
- AbstractSynchronizedSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractSynchronizedSinkConduit
- AbstractSynchronizedSinkConduit(D, Object) - Constructor for class org.xnio.conduits.AbstractSynchronizedSinkConduit
- AbstractSynchronizedSourceConduit<D> - Class in org.xnio.conduits
-
An abstract synchronized source conduit.
- AbstractSynchronizedSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractSynchronizedSourceConduit
-
Construct a new instance.
- AbstractSynchronizedSourceConduit(D, Object) - Constructor for class org.xnio.conduits.AbstractSynchronizedSourceConduit
-
Construct a new instance.
- accept() - Method in interface org.xnio.channels.AcceptingChannel
-
Attempt to accept a connection.
- accept() - Method in interface org.xnio.channels.SimpleAcceptingChannel
-
Attempt to accept a connection.
- accept(ChannelListener<? super T>, ChannelListener<? super BoundChannel>) - Method in interface org.xnio.ChannelDestination
-
Accept a connection.
- accept(Pooled<ByteBuffer>, boolean) - Method in interface org.xnio.streams.BufferPipeOutputStream.BufferWriter
-
Accept a buffer.
- acceptBlocking(A) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking accept on an accepting channel.
- acceptBlocking(A, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking accept on an accepting channel, with a timeout.
- acceptDatagram(SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- acceptFailed(AcceptingChannel<? extends ConnectedChannel>, IOException) - Method in class org.xnio._private.Messages_$logger
- acceptFailed(AcceptingChannel<? extends ConnectedChannel>, IOException) - Method in interface org.xnio._private.Messages
- acceptFailed$str() - Method in class org.xnio._private.Messages_$logger
- AcceptingChannel<C> - Interface in org.xnio.channels
-
A channel which can accept inbound connections from remote endpoints.
- AcceptListenerSettable<C> - Interface in org.xnio.channels
-
An object which supports directly setting the accept listener may implement this interface.
- AcceptListenerSettable.Setter<C> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- acceptLocalMessageConnection(LocalSocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a local (UNIX domain) datagram connection.
- acceptLocalStreamConnection(LocalSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a local (UNIX domain) stream connection.
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Accept a message connection at a destination address.
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
- acceptStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Accept a stream connection at a destination address.
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
- acceptTcpStreamConnection(InetSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a TCP connection.
- acceptWithCacheEx(int, ExceptionBiConsumer<T, U, E>, T, U) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- acceptWithCacheEx(int, ExceptionConsumer<T, E>, T) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- acknowledge(Pooled<ByteBuffer>) - Method in interface org.xnio.streams.BufferPipeInputStream.InputHandler
-
Acknowledges the successful processing of an input buffer.
- add(Map<?, ?>) - Method in class org.xnio.OptionMap.Builder
-
Add all the entries of a map.
- add(Option<?>) - Method in class org.xnio.Option.SetBuilder
-
Add an option to this set.
- add(Option<?>...) - Method in class org.xnio.Option.SetBuilder
-
Add options to this set.
- add(Option<?>, Option<?>) - Method in class org.xnio.Option.SetBuilder
-
Add options to this set.
- add(Option<?>, Option<?>, Option<?>) - Method in class org.xnio.Option.SetBuilder
-
Add options to this set.
- addAll(Collection<Option<?>>) - Method in class org.xnio.Option.SetBuilder
-
Add all options from a collection to this set.
- addAll(OptionMap) - Method in class org.xnio.OptionMap.Builder
-
Add all entries from an existing option map to the one being built.
- addBindAddressConfiguration(CidrAddress, InetAddress) - Method in class org.xnio.XnioWorker.Builder
- addBindAddressConfiguration(CidrAddress, InetSocketAddress) - Method in class org.xnio.XnioWorker.Builder
- addCancelHandler(Cancellable) - Method in class org.xnio.AbstractIoFuture
-
Add a cancellation handler.
- addCancelHandler(Cancellable) - Method in class org.xnio.FutureResult
-
Add a cancellation handler.
- ADDED - Enum constant in enum org.xnio.FileChangeEvent.Type
-
A file was added in a directory.
- addNotifier(IoFuture.Notifier<? super T, A>, A) - Method in class org.xnio.AbstractConvertingIoFuture
- addNotifier(IoFuture.Notifier<? super T, A>, A) - Method in class org.xnio.AbstractIoFuture
-
Add a notifier to be called when this operation is complete.
- addNotifier(IoFuture.Notifier<? super T, A>, A) - Method in class org.xnio.FinishedIoFuture
- addNotifier(IoFuture.Notifier<? super T, A>, A) - Method in interface org.xnio.IoFuture
-
Add a notifier to be called when this operation is complete.
- addRandom(ByteBuffer) - Static method in class org.xnio.Buffers
-
Add a random amount of random data to the target buffer using the thread-local RNG.
- addRandom(ByteBuffer, int) - Static method in class org.xnio.Buffers
-
Add
count
bytes of random data to the target buffer using the thread-local RNG. - addRandom(ByteBuffer, Random) - Static method in class org.xnio.Buffers
-
Add a random amount of random data to the target buffer.
- addRandom(ByteBuffer, Random, int) - Static method in class org.xnio.Buffers
-
Add
count
bytes of random data to the target buffer. - addressUnresolved(InetSocketAddress) - Method in class org.xnio._private.Messages_$logger
- addressUnresolved(InetSocketAddress) - Method in interface org.xnio._private.Messages
- addressUnresolved$str() - Method in class org.xnio._private.Messages_$logger
- allAreClear(int, int) - Static method in class org.xnio.Bits
-
Determine if all of the
flags
in the givenvar
are clear. - allAreClear(long, long) - Static method in class org.xnio.Bits
-
Determine if all of the
flags
in the givenvar
are clear. - allAreSet(int, int) - Static method in class org.xnio.Bits
-
Determine if all of the
flags
in the givenvar
are set. - allAreSet(long, long) - Static method in class org.xnio.Bits
-
Determine if all of the
flags
in the givenvar
are set. - allocate() - Method in class org.xnio.ByteBufferPool
-
Allocate a buffer from this source pool.
- allocate() - Method in class org.xnio.ByteBufferSlicePool
-
Deprecated.Allocate a resource from the pool.
- allocate() - Method in interface org.xnio.Pool
-
Deprecated.Allocate a resource from the pool.
- allocate(int) - Method in interface org.xnio.BufferAllocator
-
Allocate a buffer of the given size.
- allocate(ByteBuffer[], int) - Method in class org.xnio.ByteBufferPool
-
Bulk-allocate buffers from this pool.
- allocate(ByteBuffer[], int, int) - Method in class org.xnio.ByteBufferPool
-
Bulk-allocate buffers from this pool.
- allocatedBufferPool(BufferAllocator<B>, int) - Static method in class org.xnio.Buffers
-
A buffer pool which allocates a new buffer on every allocate request, and discards buffers on free.
- ALLOW_BLOCKING - Static variable in class org.xnio.Options
-
Enable or disable blocking I/O for a newly created channel thread.
- allowBlocking(boolean) - Static method in class org.xnio.Xnio
-
Allow (or disallow) blocking I/O on the current thread.
- anyAreClear(int, int) - Static method in class org.xnio.Bits
-
Determine if any of the
flags
in the givenvar
are clear. - anyAreClear(long, long) - Static method in class org.xnio.Bits
-
Determine if any of the
flags
in the givenvar
are clear. - anyAreSet(int, int) - Static method in class org.xnio.Bits
-
Determine if any of the
flags
in the givenvar
are set. - anyAreSet(long, long) - Static method in class org.xnio.Bits
-
Determine if any of the
flags
in the givenvar
are set. - appBufferTooSmall() - Method in class org.xnio._private.Messages_$logger
- appBufferTooSmall() - Method in interface org.xnio._private.Messages
- appBufferTooSmall$str() - Method in class org.xnio._private.Messages_$logger
- appendTo(ByteBuffer) - Method in class org.xnio.ByteString
-
Append the bytes of this string into the given buffer.
- applyWithCacheEx(int, ExceptionBiFunction<T, U, R, E>, T, U) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- applyWithCacheEx(int, ExceptionFunction<T, R, E>, T) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- AssembledChannel - Class in org.xnio.channels
-
A closeable view over a read and write side of a suspendable channel.
- AssembledChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledChannel
-
Construct a new instance.
- AssembledConnectedChannel - Class in org.xnio.channels
-
A closeable, connected view over a read and write side of a suspendable channel, at least one of which is connected.
- AssembledConnectedChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledConnectedChannel
-
Construct a new instance.
- AssembledConnectedMessageChannel - Class in org.xnio.channels
-
A connected bidirectional message channel assembled from a readable and writable message channel.
- AssembledConnectedMessageChannel(ConnectedChannel, ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledConnectedMessageChannel
-
Construct a new instance.
- AssembledConnectedMessageChannel(ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledConnectedMessageChannel
-
Construct a new instance.
- AssembledConnectedSslStreamChannel - Class in org.xnio.channels
-
A connected SSL stream channel assembled from a stream source and stream sink.
- AssembledConnectedSslStreamChannel(SslChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedSslStreamChannel
-
Construct a new instance.
- AssembledConnectedSslStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedSslStreamChannel
-
Construct a new instance.
- AssembledConnectedStreamChannel - Class in org.xnio.channels
-
A connected stream channel assembled from a stream source and stream sink.
- AssembledConnectedStreamChannel(ConnectedChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedStreamChannel
-
Construct a new instance.
- AssembledConnectedStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedStreamChannel
-
Construct a new instance.
- AssembledMessageChannel - Class in org.xnio.channels
-
A bidirectional message channel assembled from a readable and writable message channel.
- AssembledMessageChannel(CloseableChannel, ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledMessageChannel
-
Construct a new instance.
- AssembledMessageChannel(ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledMessageChannel
-
Construct a new instance.
- AssembledSslChannel - Class in org.xnio.channels
-
An assembled SSL channel.
- AssembledSslChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledSslChannel
-
Construct a new instance.
- AssembledStreamChannel - Class in org.xnio.channels
-
A stream channel assembled from a stream source and stream sink.
- AssembledStreamChannel(CloseableChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledStreamChannel
-
Construct a new instance.
- AssembledStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledStreamChannel
-
Construct a new instance.
- assertWritable(Buffer...) - Static method in class org.xnio.Buffers
-
Assert the writability of the given buffers.
- assertWritable(Buffer[], int, int) - Static method in class org.xnio.Buffers
-
Assert the writability of the given buffers.
- attachmentClosingNotifier() - Static method in class org.xnio.IoUtils
-
Get a notifier that closes the attachment.
- AUTH - Enum constant in enum org.xnio.sasl.SaslQop
-
A QOP value specifying authentication only.
- AUTH_CONF - Enum constant in enum org.xnio.sasl.SaslQop
-
A QOP value specifying authentication plus integrity and confidentiality protection.
- AUTH_INT - Enum constant in enum org.xnio.sasl.SaslQop
-
A QOP value specifying authentication plus integrity protection.
- AutomaticReference<T> - Class in org.xnio
-
Deprecated.
- AutomaticReference(T, Object) - Constructor for class org.xnio.AutomaticReference
-
Deprecated.Construct a new instance.
- available() - Method in class org.xnio.streams.BufferedChannelInputStream
-
Return the number of bytes available to read, or 0 if a subsequent
read()
operation would block. - available() - Method in class org.xnio.streams.BufferPipeInputStream
- available() - Method in class org.xnio.streams.LimitedInputStream
- available() - Method in class org.xnio.streams.ReaderInputStream
- await() - Method in class org.xnio.AbstractConvertingIoFuture
- await() - Method in class org.xnio.AbstractIoFuture
-
Wait for the operation to complete.
- await() - Method in class org.xnio.FinishedIoFuture
- await() - Method in interface org.xnio.IoFuture
-
Wait for the operation to complete.
- await() - Method in class org.xnio.streams.Pipe
-
Wait for the read side to close.
- await(long, TimeUnit) - Method in class org.xnio.AbstractConvertingIoFuture
- await(long, TimeUnit) - Method in class org.xnio.AbstractIoFuture
-
Wait for the operation to complete, with a timeout.
- await(long, TimeUnit) - Method in class org.xnio.FinishedIoFuture
- await(long, TimeUnit) - Method in interface org.xnio.IoFuture
-
Wait for the operation to complete, with a timeout.
- awaitAcceptable() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Block until this channel becomes acceptable again.
- awaitAcceptable(long, TimeUnit) - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Block until this channel becomes acceptable again, or until the timeout expires.
- awaitAll(IoFuture<?>...) - Static method in class org.xnio.IoUtils
-
Wait for all the futures to complete.
- awaitAllInterruptibly(IoFuture<?>...) - Static method in class org.xnio.IoUtils
-
Wait for all the futures to complete.
- awaitInterruptibly() - Method in class org.xnio.AbstractConvertingIoFuture
- awaitInterruptibly() - Method in class org.xnio.AbstractIoFuture
-
Wait for the operation to complete.
- awaitInterruptibly() - Method in class org.xnio.FinishedIoFuture
- awaitInterruptibly() - Method in interface org.xnio.IoFuture
-
Wait for the operation to complete.
- awaitInterruptibly(long, TimeUnit) - Method in class org.xnio.AbstractConvertingIoFuture
- awaitInterruptibly(long, TimeUnit) - Method in class org.xnio.AbstractIoFuture
-
Wait for the operation to complete, with a timeout.
- awaitInterruptibly(long, TimeUnit) - Method in class org.xnio.FinishedIoFuture
- awaitInterruptibly(long, TimeUnit) - Method in interface org.xnio.IoFuture
-
Wait for the operation to complete, with a timeout.
- awaitReadable() - Method in class org.xnio.channels.AssembledMessageChannel
- awaitReadable() - Method in class org.xnio.channels.AssembledStreamChannel
- awaitReadable() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- awaitReadable() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- awaitReadable() - Method in class org.xnio.channels.PushBackStreamChannel
- awaitReadable() - Method in class org.xnio.channels.SplitStreamSourceChannel
- awaitReadable() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Block until this channel becomes readable again.
- awaitReadable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Block until this channel becomes readable again.
- awaitReadable() - Method in class org.xnio.conduits.AbstractSourceConduit
- awaitReadable() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- awaitReadable() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- awaitReadable() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- awaitReadable() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- awaitReadable() - Method in class org.xnio.conduits.FramingMessageSourceConduit
- awaitReadable() - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- awaitReadable() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- awaitReadable() - Method in interface org.xnio.conduits.SourceConduit
-
Block until this channel becomes readable again.
- awaitReadable() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.AssembledMessageChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.AssembledStreamChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.PushBackStreamChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.SplitStreamSourceChannel
- awaitReadable(long, TimeUnit) - Method in interface org.xnio.channels.SuspendableReadChannel
-
Block until this channel becomes readable again, or until the timeout expires.
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Block until this channel becomes readable again, or until the timeout expires.
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSourceConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.FramingMessageSourceConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- awaitReadable(long, TimeUnit) - Method in interface org.xnio.conduits.SourceConduit
-
Block until this conduit becomes readable again, or until the timeout expires.
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- awaitTermination() - Method in class org.xnio.XnioWorker
-
Wait for termination.
- awaitTermination(long, TimeUnit) - Method in class org.xnio.XnioWorker
-
Wait for termination.
- awaitWritable() - Method in class org.xnio.channels.AssembledMessageChannel
- awaitWritable() - Method in class org.xnio.channels.AssembledStreamChannel
- awaitWritable() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- awaitWritable() - Method in class org.xnio.channels.NullStreamSinkChannel
- awaitWritable() - Method in class org.xnio.channels.SplitStreamSinkChannel
- awaitWritable() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Block until this channel becomes writable again.
- awaitWritable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Block until this channel becomes writable again.
- awaitWritable() - Method in class org.xnio.conduits.AbstractSinkConduit
- awaitWritable() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- awaitWritable() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- awaitWritable() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- awaitWritable() - Method in class org.xnio.conduits.NullStreamSinkConduit
- awaitWritable() - Method in interface org.xnio.conduits.SinkConduit
-
Block until this channel becomes writable again.
- awaitWritable() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.AssembledMessageChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.AssembledStreamChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.NullStreamSinkChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.SplitStreamSinkChannel
- awaitWritable(long, TimeUnit) - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Block until this channel becomes writable again, or until the timeout expires.
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Block until this channel becomes writable again, or until the timeout expires.
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSinkConduit
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.NullStreamSinkConduit
- awaitWritable(long, TimeUnit) - Method in interface org.xnio.conduits.SinkConduit
-
Block until this conduit becomes writable again, or until the timeout expires.
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
B
- BACKLOG - Static variable in class org.xnio.Options
-
Configure a server with the specified backlog.
- badCompressionFormat() - Method in class org.xnio._private.Messages_$logger
- badCompressionFormat() - Method in interface org.xnio._private.Messages
- badCompressionFormat$str() - Method in class org.xnio._private.Messages_$logger
- badSockType(Class<? extends SocketAddress>) - Method in class org.xnio._private.Messages_$logger
- badSockType(Class<? extends SocketAddress>) - Method in interface org.xnio._private.Messages
- badSockType$str() - Method in class org.xnio._private.Messages_$logger
- BALANCING_CONNECTIONS - Static variable in class org.xnio.Options
-
The number of connections to create per connection-balancing token, if connection-balancing is enabled.
- BALANCING_TOKENS - Static variable in class org.xnio.Options
-
The number of balancing tokens, if connection-balancing is enabled.
- Bits - Class in org.xnio
-
General bit-affecting utility methods.
- block(InetAddress) - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Block multicast packets from the given source address.
- BlockingByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a
StreamChannel
. - BlockingByteChannel(StreamChannel) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- BlockingByteChannel(StreamChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- BlockingByteChannel(StreamChannel, long, TimeUnit, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- blockingNotAllowed() - Method in class org.xnio._private.Messages_$logger
- blockingNotAllowed() - Method in interface org.xnio._private.Messages
- blockingNotAllowed$str() - Method in class org.xnio._private.Messages_$logger
- BlockingReadableByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a
StreamSourceChannel
. - BlockingReadableByteChannel(StreamSourceChannel) - Constructor for class org.xnio.channels.BlockingReadableByteChannel
-
Construct a new instance.
- BlockingReadableByteChannel(StreamSourceChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingReadableByteChannel
-
Construct a new instance.
- BlockingStreamSinkConduit - Class in org.xnio.conduits
- BlockingStreamSinkConduit(StreamSinkConduit) - Constructor for class org.xnio.conduits.BlockingStreamSinkConduit
- BlockingStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which can switch into and out of blocking mode.
- BlockingStreamSourceConduit(StreamSourceConduit) - Constructor for class org.xnio.conduits.BlockingStreamSourceConduit
-
Construct a new instance.
- BlockingWritableByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a
StreamChannel
. - BlockingWritableByteChannel(StreamSinkChannel) - Constructor for class org.xnio.channels.BlockingWritableByteChannel
-
Construct a new instance.
- BlockingWritableByteChannel(StreamSinkChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingWritableByteChannel
-
Construct a new instance.
- BoundChannel - Interface in org.xnio.channels
-
A channel that is bound to a local address.
- BoundMultipointMessageChannel - Interface in org.xnio.channels
-
A multipoint datagram channel.
- breakPipe() - Method in class org.xnio.streams.BufferPipeOutputStream
-
Break the pipe and return any filling pooled buffer.
- BROADCAST - Static variable in class org.xnio.Options
-
Enable broadcast support for IP datagram sockets.
- BrokenPipeException - Exception Class in org.xnio
-
An exception that signifies that a pipe, stream, or channel was closed from the read side while the write side was still writing.
- BrokenPipeException() - Constructor for exception class org.xnio.BrokenPipeException
-
Constructs a
BrokenPipeException
with no detail message. - BrokenPipeException(String) - Constructor for exception class org.xnio.BrokenPipeException
-
Constructs a
BrokenPipeException
with the specified detail message. - BrokenPipeException(String, Throwable) - Constructor for exception class org.xnio.BrokenPipeException
-
Constructs a
BrokenPipeException
with the specified detail message and cause. - BrokenPipeException(Throwable) - Constructor for exception class org.xnio.BrokenPipeException
-
Constructs a
BrokenPipeException
with the specified cause. - BufferAllocator<B> - Interface in org.xnio
-
A simple allocator for buffers.
- BufferedChannelInputStream - Class in org.xnio.streams
-
An input stream which reads from a stream source channel with a buffer.
- BufferedChannelInputStream(StreamSourceChannel, int) - Constructor for class org.xnio.streams.BufferedChannelInputStream
-
Construct a new instance.
- BufferedChannelInputStream(StreamSourceChannel, int, long, TimeUnit) - Constructor for class org.xnio.streams.BufferedChannelInputStream
-
Construct a new instance.
- BufferedStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit that buffers output data.
- BufferedStreamSinkConduit(StreamSinkConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.BufferedStreamSinkConduit
-
Construct a new instance.
- BufferedStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which buffers input.
- BufferedStreamSourceConduit(StreamSourceConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.BufferedStreamSourceConduit
-
Construct a new instance.
- bufferFreed() - Method in class org.xnio._private.Messages_$logger
- bufferFreed() - Method in interface org.xnio._private.Messages
- bufferFreed$str() - Method in class org.xnio._private.Messages_$logger
- bufferOverflow() - Method in class org.xnio._private.Messages_$logger
- bufferOverflow() - Method in interface org.xnio._private.Messages
- bufferOverflow$str() - Method in class org.xnio._private.Messages_$logger
- BufferPipeInputStream - Class in org.xnio.streams
-
An
InputStream
implementation which is populated asynchronously withByteBuffer
instances. - BufferPipeInputStream(BufferPipeInputStream.InputHandler) - Constructor for class org.xnio.streams.BufferPipeInputStream
-
Construct a new instance.
- BufferPipeInputStream.InputHandler - Interface in org.xnio.streams
-
A handler for events relating to the consumption of data from a
BufferPipeInputStream
instance. - BufferPipeOutputStream - Class in org.xnio.streams
-
An
OutputStream
implementation which writes outByteBuffer
s to a consumer. - BufferPipeOutputStream(BufferPipeOutputStream.BufferWriter) - Constructor for class org.xnio.streams.BufferPipeOutputStream
-
Construct a new instance.
- BufferPipeOutputStream.BufferWriter - Interface in org.xnio.streams
-
A buffer writer for an
BufferPipeOutputStream
. - Buffers - Class in org.xnio
-
Buffer utility methods.
- bufferUnderflow() - Method in class org.xnio._private.Messages_$logger
- bufferUnderflow() - Method in interface org.xnio._private.Messages
- bufferUnderflow$str() - Method in class org.xnio._private.Messages_$logger
- build() - Method in class org.xnio.XnioWorker.Builder
- build(XnioWorker.Builder) - Method in class org.xnio.Xnio
-
Construct an XNIO worker from a builder.
- builder() - Static method in class org.xnio.OptionMap
-
Create a new builder.
- Builder(Xnio) - Constructor for class org.xnio.XnioWorker.Builder
-
Construct a new instance.
- BYTE_BUFFER_ALLOCATOR - Static variable in interface org.xnio.BufferAllocator
-
A simple allocator for heap-array-backed byte buffers.
- byteAt(int) - Method in class org.xnio.ByteString
-
Get the byte at an index.
- ByteBufferPool - Class in org.xnio
-
A fast source of pooled buffers.
- ByteBufferPool.Set - Class in org.xnio
-
A set of buffer pools for each size, which can either be
ByteBufferPool.Set.DIRECT
orByteBufferPool.Set.HEAP
. - ByteBufferSlicePool - Class in org.xnio
-
Deprecated.See
ByteBufferPool
. - ByteBufferSlicePool(int, int) - Constructor for class org.xnio.ByteBufferSlicePool
-
Deprecated.Construct a new instance, using a direct buffer allocator.
- ByteBufferSlicePool(BufferAllocator<ByteBuffer>, int, int) - Constructor for class org.xnio.ByteBufferSlicePool
-
Deprecated.Construct a new instance.
- ByteBufferSlicePool(BufferAllocator<ByteBuffer>, int, int, int) - Constructor for class org.xnio.ByteBufferSlicePool
-
Deprecated.Construct a new instance.
- ByteChannel - Interface in org.xnio.channels
-
An extension of a simple NIO
ByteChannel
which includes scatter/gather operations. - ByteString - Class in org.xnio
-
An immutable string of bytes.
C
- callNext(T) - Method in class org.xnio.DelegatingChannelListener
-
Call the next listener.
- cancel() - Method in class org.xnio.AbstractConvertingIoFuture
- cancel() - Method in class org.xnio.AbstractIoFuture
-
Cancel an operation.
- cancel() - Method in interface org.xnio.Cancellable
-
Cancel an operation.
- cancel() - Method in class org.xnio.FailedIoFuture
-
Cancel the operation.
- cancel() - Method in class org.xnio.FinishedIoFuture
-
Cancel the operation.
- cancel() - Method in interface org.xnio.IoFuture
-
Cancel an operation.
- Cancellable - Interface in org.xnio
-
An operation which may be cancelled.
- CANCELLED - Enum constant in enum org.xnio.IoFuture.Status
-
The operation was cancelled.
- cantInstantiate(Class<?>, Throwable) - Method in class org.xnio._private.Messages_$logger
- cantInstantiate(Class<?>, Throwable) - Method in interface org.xnio._private.Messages
- cantInstantiate$str() - Method in class org.xnio._private.Messages_$logger
- cast(Class<N>) - Method in class org.xnio.Sequence
-
Cast a sequence to a different type if all the contained elements are of the subtype.
- cast(Object) - Method in class org.xnio.Option
-
Return the given object as the type of this option.
- cast(Object, T) - Method in class org.xnio.Option
-
Return the given object as the type of this option.
- cast(IoFuture<I>, Class<O>) - Static method in class org.xnio.IoUtils
-
Create an
IoFuture
which wraps anotherIoFuture
, but returns a different type. - ChainedChannelListener<T> - Class in org.xnio
-
A channel listener that chains calls to a number of other channel listeners.
- ChainedChannelListener(ChannelListener<? super T>...) - Constructor for class org.xnio.ChainedChannelListener
-
Construct a new instance.
- channel - Variable in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.The wrapped channel.
- channel - Variable in class org.xnio.streams.ChannelInputStream
- channel - Variable in class org.xnio.streams.ChannelOutputStream
- ChannelDestination<T> - Interface in org.xnio
-
A channel destination.
- ChannelExceptionHandler<T> - Interface in org.xnio
-
An exception handler for utility channel listeners.
- ChannelFactory<C> - Interface in org.xnio.channels
-
A generalized channel factory type.
- ChannelInputStream - Class in org.xnio.streams
-
An input stream which reads from a stream source channel.
- ChannelInputStream(StreamSourceChannel) - Constructor for class org.xnio.streams.ChannelInputStream
-
Construct a new instance.
- ChannelInputStream(StreamSourceChannel, long, TimeUnit) - Constructor for class org.xnio.streams.ChannelInputStream
-
Construct a new instance.
- ChannelListener<T> - Interface in org.xnio
-
A listener for channel events.
- ChannelListener.Setter<T> - Interface in org.xnio
-
A setter for a channel listener.
- ChannelListener.SimpleSetter<T> - Class in org.xnio
-
A simple implementation of
ChannelListener.Setter
. - ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
-
Construct a new instance.
- ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
-
Construct a new instance.
- ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
-
Construct a new instance.
- channelListenerNotifier() - Static method in class org.xnio.IoUtils
-
Get the notifier that invokes the channel listener given as an attachment.
- ChannelListeners - Class in org.xnio
-
Channel listener utility methods.
- channelNotAvailable() - Method in class org.xnio._private.Messages_$logger
- channelNotAvailable() - Method in interface org.xnio._private.Messages
- channelNotAvailable$str() - Method in class org.xnio._private.Messages_$logger
- ChannelOutputStream - Class in org.xnio.streams
-
An output stream which writes to a stream sink channel.
- ChannelOutputStream(StreamSinkChannel) - Constructor for class org.xnio.streams.ChannelOutputStream
-
Construct a new instance.
- ChannelOutputStream(StreamSinkChannel, long, TimeUnit) - Constructor for class org.xnio.streams.ChannelOutputStream
-
Construct a new instance.
- ChannelPipe<L,
R> - Class in org.xnio -
A one-way pipe.
- ChannelPipe(L, R) - Constructor for class org.xnio.ChannelPipe
-
Construct a new instance.
- Channels - Class in org.xnio.channels
-
A utility class containing static methods to support channel usage.
- ChannelSource<T> - Interface in org.xnio
-
A channel source.
- characterDecodingProblem() - Method in class org.xnio._private.Messages_$logger
- characterDecodingProblem() - Method in interface org.xnio._private.Messages
- characterDecodingProblem$str() - Method in class org.xnio._private.Messages_$logger
- charAt(int) - Method in class org.xnio.ByteString
- charFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed big-endian char value from a byte array.
- charFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed little-endian char value from a byte array.
- checkBlockingAllowed() - Static method in class org.xnio.Xnio
-
Perform a check for whether blocking is allowed on the current thread.
- checkHandshake(Map<String, String>) - Method in interface org.xnio.http.HandshakeChecker
-
Checks a handshake, and throws an exception if it is invalid
- checkHandshakeExtended(Map<String, List<String>>) - Method in interface org.xnio.http.ExtendedHandshakeChecker
-
Checks a handshake, and throws an exception if it is invalid
- chooseThread() - Method in class org.xnio.XnioWorker
-
Choose a thread randomly from this worker.
- classNotFound(String, ClassNotFoundException) - Method in class org.xnio._private.Messages_$logger
- classNotFound(String, ClassNotFoundException) - Method in interface org.xnio._private.Messages
- classNotFound$str() - Method in class org.xnio._private.Messages_$logger
- classNotInstance(String, Class<?>) - Method in class org.xnio._private.Messages_$logger
- classNotInstance(String, Class<?>) - Method in interface org.xnio._private.Messages
- classNotInstance$str() - Method in class org.xnio._private.Messages_$logger
- clean() - Method in class org.xnio.ByteBufferSlicePool
-
Deprecated.Cleans the pool, removing references to any buffers inside it.
- clear() - Method in class org.xnio.AutomaticReference
-
Deprecated.Not supported.
- clear() - Method in class org.xnio.channels.SocketAddressBuffer
-
Clear both addresses in the buffer.
- clear(T) - Static method in class org.xnio.Buffers
-
Clear a buffer.
- clearReadReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel is no longer definitely immediately readable.
- clearReadRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel no longer requires writability for reads to proceed.
- clearWriteReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel is no longer definitely immediately writable.
- clearWriteRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel no longer requires writability for writes to proceed.
- clone() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Duplicate this channel.
- close() - Method in class org.xnio.channels.AssembledChannel
- close() - Method in class org.xnio.channels.AssembledMessageChannel
- close() - Method in class org.xnio.channels.AssembledStreamChannel
- close() - Method in class org.xnio.channels.BlockingByteChannel
- close() - Method in class org.xnio.channels.BlockingReadableByteChannel
- close() - Method in class org.xnio.channels.BlockingWritableByteChannel
- close() - Method in interface org.xnio.channels.CloseableChannel
-
Close this channel.
- close() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- close() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- close() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- close() - Method in class org.xnio.channels.NullStreamSinkChannel
- close() - Method in class org.xnio.channels.PushBackStreamChannel
- close() - Method in class org.xnio.channels.SplitStreamSinkChannel
- close() - Method in class org.xnio.channels.SplitStreamSourceChannel
- close() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Close this channel.
- close() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Close this channel.
- close() - Method in class org.xnio.conduits.ConduitReadableByteChannel
- close() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- close() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- close() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- close() - Method in class org.xnio.conduits.ConduitWritableByteChannel
- close() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- close() - Method in class org.xnio.Connection
- close() - Method in interface org.xnio.ManagementRegistration
- close() - Method in interface org.xnio.Pooled
-
Deprecated.Delegates to
Pooled.free()
. - close() - Method in class org.xnio.streams.BufferedChannelInputStream
-
Close the stream.
- close() - Method in class org.xnio.streams.BufferPipeInputStream
- close() - Method in interface org.xnio.streams.BufferPipeInputStream.InputHandler
-
Signifies that the user of the enclosing
BufferPipeInputStream
has called theclose()
method explicitly. - close() - Method in class org.xnio.streams.BufferPipeOutputStream
- close() - Method in class org.xnio.streams.ChannelInputStream
- close() - Method in class org.xnio.streams.ChannelOutputStream
- close() - Method in class org.xnio.streams.LimitedInputStream
- close() - Method in class org.xnio.streams.LimitedOutputStream
- close() - Method in class org.xnio.streams.ReaderInputStream
- close() - Method in class org.xnio.streams.WriterOutputStream
- CLOSE_ABORT - Static variable in class org.xnio.Options
-
Configure a TCP socket to send an
RST
packet on close. - CloseableChannel - Interface in org.xnio.channels
-
A channel which is closeable.
- closeAction() - Method in class org.xnio.Connection
-
The close action to perform on this connection.
- closeAction() - Method in class org.xnio.ssl.JsseSslConnection
- closeAction() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
The close action to perform on this connection.
- closeAction(boolean, boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- closeAction(boolean, boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.The action to perform when the channel is closed via the
TranslatingSuspendableChannel.close()
method. - ClosedWorkerException - Exception Class in org.xnio
-
A channel open was attempted on a closed worker.
- ClosedWorkerException() - Constructor for exception class org.xnio.ClosedWorkerException
-
Constructs a
ClosedWorkerException
with no detail message. - ClosedWorkerException(String) - Constructor for exception class org.xnio.ClosedWorkerException
-
Constructs a
ClosedWorkerException
with the specified detail message. - ClosedWorkerException(String, Throwable) - Constructor for exception class org.xnio.ClosedWorkerException
-
Constructs a
ClosedWorkerException
with the specified detail message and cause. - ClosedWorkerException(Throwable) - Constructor for exception class org.xnio.ClosedWorkerException
-
Constructs a
ClosedWorkerException
with the specified cause. - CloseListenerSettable<C> - Interface in org.xnio.channels
-
An object which supports directly setting the close listener may implement this interface.
- CloseListenerSettable.Setter<C> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- closeMsg - Static variable in interface org.xnio._private.Messages
- Closer - Class in org.xnio
-
A
Runnable
that closes some resource. - Closer(Closeable) - Constructor for class org.xnio.Closer
- closingCancellable(Closeable) - Static method in class org.xnio.IoUtils
-
A cancellable which closes the given resource on cancel.
- closingChannelExceptionHandler() - Static method in class org.xnio.ChannelListeners
-
Get a channel exception handler which closes the channel upon exception.
- closingChannelListener() - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the channel when notified.
- closingChannelListener(Closeable) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingChannelListener(Closeable...) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resources when notified.
- closingChannelListener(ChannelListener<T>, Closeable) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingChannelListener(ChannelListener<T>, Closeable...) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingNotifier() - Static method in class org.xnio.IoUtils
-
Get a notifier that closes the result.
- closingResource(Object) - Method in class org.xnio._private.Messages_$logger
- closingResource(Object) - Method in interface org.xnio._private.Messages
- closingResource$str() - Method in class org.xnio._private.Messages_$logger
- compareTo(ByteString) - Method in class org.xnio.ByteString
-
Compare this string to another in a case-sensitive manner.
- compareToIgnoreCase(ByteString) - Method in class org.xnio.ByteString
-
Compare this string to another in a case-insensitive manner.
- COMPRESSION_LEVEL - Static variable in class org.xnio.Options
-
The compression level to apply for compressing streams and channels.
- COMPRESSION_TYPE - Static variable in class org.xnio.Options
-
The compression type to apply for compressing streams and channels.
- CompressionType - Enum in org.xnio
-
Supported compression types.
- concat(byte[]) - Method in class org.xnio.ByteString
- concat(byte[], int, int) - Method in class org.xnio.ByteString
- concat(String) - Method in class org.xnio.ByteString
- concat(String, int, int) - Method in class org.xnio.ByteString
- concat(String, String) - Static method in class org.xnio.ByteString
- concat(String, ByteString) - Static method in class org.xnio.ByteString
- concat(ByteString) - Method in class org.xnio.ByteString
- concat(ByteString, int, int) - Method in class org.xnio.ByteString
- concurrentAccess() - Method in class org.xnio._private.Messages_$logger
- concurrentAccess() - Method in interface org.xnio._private.Messages
- concurrentAccess$str() - Method in class org.xnio._private.Messages_$logger
- ConcurrentStreamChannelAccessException - Exception Class in org.xnio.channels
-
An exception which is thrown when more than one thread tries to access a stream channel at once.
- ConcurrentStreamChannelAccessException() - Constructor for exception class org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a
ConcurrentStreamChannelAccessException
with no detail message. - ConcurrentStreamChannelAccessException(String) - Constructor for exception class org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a
ConcurrentStreamChannelAccessException
with the specified detail message. - ConcurrentStreamChannelAccessException(String, Throwable) - Constructor for exception class org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a
ConcurrentStreamChannelAccessException
with the specified detail message and cause. - ConcurrentStreamChannelAccessException(Throwable) - Constructor for exception class org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a
ConcurrentStreamChannelAccessException
with the specified cause. - Conduit - Interface in org.xnio.conduits
-
A conduit, or stage which data transfer is processed by or provided by.
- ConduitReadableByteChannel - Class in org.xnio.conduits
-
A byte channel which wraps a conduit.
- ConduitReadableByteChannel(StreamSourceConduit) - Constructor for class org.xnio.conduits.ConduitReadableByteChannel
-
Construct a new instance.
- ConduitReadableMessageChannel - Class in org.xnio.conduits
-
A readable message channel which is backed by a message source conduit.
- ConduitReadableMessageChannel(Configurable, MessageSourceConduit) - Constructor for class org.xnio.conduits.ConduitReadableMessageChannel
-
Construct a new instance.
- Conduits - Class in org.xnio.conduits
-
General utility methods for manipulating conduits.
- Conduits() - Constructor for class org.xnio.conduits.Conduits
- ConduitStreamSinkChannel - Class in org.xnio.conduits
-
A stream sink channel which wraps a stream sink conduit.
- ConduitStreamSinkChannel(Configurable, StreamSinkConduit) - Constructor for class org.xnio.conduits.ConduitStreamSinkChannel
-
Construct a new instance.
- ConduitStreamSourceChannel - Class in org.xnio.conduits
-
A stream source channel which wraps a stream source conduit.
- ConduitStreamSourceChannel(Configurable, StreamSourceConduit) - Constructor for class org.xnio.conduits.ConduitStreamSourceChannel
-
Construct a new instance.
- ConduitWritableByteChannel - Class in org.xnio.conduits
-
A byte channel which wraps a conduit.
- ConduitWritableByteChannel(StreamSinkConduit) - Constructor for class org.xnio.conduits.ConduitWritableByteChannel
-
Construct a new instance.
- ConduitWritableMessageChannel - Class in org.xnio.conduits
-
A writable message channel which is backed by a message sink conduit.
- ConduitWritableMessageChannel(Configurable, MessageSinkConduit) - Constructor for class org.xnio.conduits.ConduitWritableMessageChannel
-
Construct a new instance.
- Configurable - Interface in org.xnio.channels
-
A channel that has parameters that may be configured while the channel is open.
- connectDatagram(SocketAddress, SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectDatagram(SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- ConnectedChannel - Interface in org.xnio.channels
-
A channel that has a local and peer endpoint address.
- ConnectedMessageChannel - Interface in org.xnio.channels
-
A channel that sends and receives messages to a connected peer.
- ConnectedSslStreamChannel - Interface in org.xnio.channels
-
A TLS-encapsulated connected stream channel.
- ConnectedStreamChannel - Interface in org.xnio.channels
-
A stream channel that is a connection between a local and remote endpoint.
- Connection - Class in org.xnio
-
The base for all connections.
- Connection(XnioIoThread) - Constructor for class org.xnio.Connection
-
Construct a new instance.
- CONNECTION_HIGH_WATER - Static variable in class org.xnio.Options
-
The high water mark for a server's connections.
- CONNECTION_LOW_WATER - Static variable in class org.xnio.Options
-
The low water mark for a server's connections.
- connectionClosedEarly() - Method in class org.xnio._private.Messages_$logger
- connectionClosedEarly() - Method in interface org.xnio._private.Messages
- connectionClosedEarly$str() - Method in class org.xnio._private.Messages_$logger
- ConnectionClosedEarlyException - Exception Class in org.xnio.http
-
Exception thrown if the connection is unexpectedly closed during http upgrade before the response can be fully read.
- ConnectionClosedEarlyException() - Constructor for exception class org.xnio.http.ConnectionClosedEarlyException
-
Constructs a new
ConnectionClosedEarlyException
instance. - ConnectionClosedEarlyException(String) - Constructor for exception class org.xnio.http.ConnectionClosedEarlyException
-
Constructs a new
ConnectionClosedEarlyException
instance with an initial message. - ConnectionClosedEarlyException(String, Throwable) - Constructor for exception class org.xnio.http.ConnectionClosedEarlyException
-
Constructs a new
ConnectionClosedEarlyException
instance with an initial message and cause. - ConnectionClosedEarlyException(Throwable) - Constructor for exception class org.xnio.http.ConnectionClosedEarlyException
-
Constructs a new
ConnectionClosedEarlyException
instance with an initial cause. - connectionNotifyReadClosedFailed(Throwable, StreamConnection) - Method in class org.xnio._private.Messages_$logger
- connectionNotifyReadClosedFailed(Throwable, StreamConnection) - Method in interface org.xnio._private.Messages
- connectionNotifyReadClosedFailed$str() - Method in class org.xnio._private.Messages_$logger
- connectionNotifyWriteClosedFailed(Throwable, StreamConnection) - Method in class org.xnio._private.Messages_$logger
- connectionNotifyWriteClosedFailed(Throwable, StreamConnection) - Method in interface org.xnio._private.Messages
- connectionNotifyWriteClosedFailed$str() - Method in class org.xnio._private.Messages_$logger
- connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
- connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectStream(SocketAddress, SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- contains(String) - Method in class org.xnio.ByteString
-
Determine whether this string contains another string (case-sensitive).
- contains(ByteString) - Method in class org.xnio.ByteString
-
Determine whether this string contains another string (case-sensitive).
- contains(Option<?>) - Method in class org.xnio.OptionMap
-
Determine whether this option map contains the given option.
- containsIgnoreCase(String) - Method in class org.xnio.ByteString
-
Determine whether this string contains another string (case-sensitive).
- containsIgnoreCase(ByteString) - Method in class org.xnio.ByteString
-
Determine whether this string contains another string (case-insensitive).
- convert(D) - Method in class org.xnio.AbstractConvertingIoFuture
- copy(int, ByteBuffer[], int, int, ByteBuffer) - Static method in class org.xnio.Buffers
-
Copy at most
count
bytes fromsources
intodestinations
in a "scatter" fashion. - copy(int, ByteBuffer, ByteBuffer) - Static method in class org.xnio.Buffers
-
Copy at most
count
bytes fromsource
intodestination
. - copy(int, ByteBuffer, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Copy at most
count
bytes fromsources
intodestination
in a "gather" fashion. - copy(long, ByteBuffer[], int, int, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Copy at most
count
bytes fromsources
intodestinations
by a combined "scatter"/"gather" operation. - copy(ByteBuffer[], int, int, ByteBuffer) - Static method in class org.xnio.Buffers
-
Copy as many bytes as possible from
sources
intodestinations
in a "scatter" fashion. - copy(ByteBuffer[], int, int, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Copy as many bytes as possible from
sources
intodestinations
by a combined "scatter"/"gather" operation. - copy(ByteBuffer, int, BufferAllocator<ByteBuffer>) - Static method in class org.xnio.Buffers
-
Copy a portion of the buffer into a newly allocated buffer.
- copy(ByteBuffer, ByteBuffer) - Static method in class org.xnio.Buffers
-
Copy as many bytes as possible from
source
intodestination
. - copy(ByteBuffer, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Copy as many bytes as possible from
sources
intodestination
in a "gather" fashion. - copyNegative() - Method in class org.xnio._private.Messages_$logger
- copyNegative() - Method in interface org.xnio._private.Messages
- copyNegative$str() - Method in class org.xnio._private.Messages_$logger
- copyOf(byte[], int, int) - Static method in class org.xnio.ByteString
-
Create a byte string from the given array segment.
- copyStream(InputStream, OutputStream) - Static method in class org.xnio.streams.Streams
-
Copy from one stream to another.
- copyStream(InputStream, OutputStream, boolean) - Static method in class org.xnio.streams.Streams
-
Copy from one stream to another.
- copyStream(InputStream, OutputStream, boolean, int) - Static method in class org.xnio.streams.Streams
-
Copy from one stream to another.
- copyTo(byte[]) - Method in class org.xnio.ByteString
-
Copy all the bytes from this string to the given array at the given offset.
- copyTo(byte[], int) - Method in class org.xnio.ByteString
-
Copy all the bytes from this string to the given array at the given offset.
- copyTo(byte[], int, int) - Method in class org.xnio.ByteString
-
Copy
len
bytes from this string to the given array at the given offset. - copyTo(int, byte[], int, int) - Method in class org.xnio.ByteString
-
Copy
len
bytes from this string at offsetsrcOffs
to the given array at the given offset. - CORK - Static variable in class org.xnio.Options
-
Specify that output should be buffered.
- create() - Method in interface org.xnio.channels.ChannelFactory
-
Create the channel instance.
- create() - Method in class org.xnio.Option.SetBuilder
-
Create the immutable option set instance.
- create(SaslClient) - Static method in class org.xnio.sasl.SaslWrapper
-
Create a SASL wrapper for a SASL client.
- create(SaslServer) - Static method in class org.xnio.sasl.SaslWrapper
-
Create a SASL wrapper for a SASL server.
- create(Option<T>, T) - Static method in class org.xnio.OptionMap
-
Create a single-valued option map.
- create(Option<T1>, T1, Option<T2>, T2) - Static method in class org.xnio.OptionMap
-
Create a two-valued option map.
- createDumper(ByteBuffer, int, int) - Static method in class org.xnio.Buffers
-
Create an object that returns the dumped form of the given byte buffer when its
toString()
method is called. - createDumper(CharBuffer, int, int) - Static method in class org.xnio.Buffers
-
Create an object that returns the dumped form of the given character buffer when its
toString()
method is called. - createFileSystemWatcher(String, OptionMap) - Method in class org.xnio.Xnio
-
Creates a file system watcher, that can be used to monitor file system changes.
- createFullDuplexPipe() - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipe() - Method in class org.xnio.XnioIoThread
- createFullDuplexPipe() - Method in class org.xnio.XnioWorker
- createFullDuplexPipeConnection() - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipeConnection() - Method in class org.xnio.XnioIoThread
- createFullDuplexPipeConnection() - Method in class org.xnio.XnioWorker
- createFullDuplexPipeConnection(XnioIoFactory) - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipeConnection(XnioIoFactory) - Method in class org.xnio.XnioIoThread
- createFullDuplexPipeConnection(XnioIoFactory) - Method in class org.xnio.XnioWorker
- createHalfDuplexPipe() - Method in interface org.xnio.XnioIoFactory
-
Create a one-way stream pipe.
- createHalfDuplexPipe() - Method in class org.xnio.XnioIoThread
- createHalfDuplexPipe() - Method in class org.xnio.XnioWorker
- createHalfDuplexPipe(XnioIoFactory) - Method in interface org.xnio.XnioIoFactory
-
Create a one-way stream pipe.
- createHalfDuplexPipe(XnioIoFactory) - Method in class org.xnio.XnioIoThread
- createHalfDuplexPipe(XnioIoFactory) - Method in class org.xnio.XnioWorker
- createLocalStreamConnectionServer(LocalSocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Implementation helper method to create a UNIX domain stream server.
- createOneWayPipe(ChannelListener<? super StreamSourceChannel>, ChannelListener<? super StreamSinkChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.Users should prefer the simpler
XnioWorker.createHalfDuplexPipe()
instead. - createPipe(ChannelListener<? super StreamChannel>, ChannelListener<? super StreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.Users should prefer the simpler
XnioWorker.createFullDuplexPipe()
instead. - createPropertyMap(OptionMap, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Create a SASL property map from an XNIO option map.
- createSslConnectionServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<SslConnection>>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
- createSslConnectionServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<SslConnection>>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create a bound TCP SSL server.
- createSSLContext(KeyManager[], TrustManager[], SecureRandom, OptionMap) - Static method in class org.xnio.ssl.JsseSslUtils
-
Create a new SSL context, configured from an option map and the given parameters.
- createSSLContext(OptionMap) - Static method in class org.xnio.ssl.JsseSslUtils
-
Create a new SSL context, configured from an option map.
- createSSLEngine(SSLContext, OptionMap, InetSocketAddress) - Static method in class org.xnio.ssl.JsseSslUtils
-
Create a new client mode SSL engine, configured from an option map.
- createSslTcpServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<ConnectedSslStreamChannel>>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
- createSslTcpServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<ConnectedSslStreamChannel>>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- createStreamConnectionServer(SocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream server, for TCP or UNIX domain servers.
- createStreamServer(SocketAddress, ChannelListener<? super AcceptingChannel<ConnectedStreamChannel>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- createTcpConnectionServer(InetSocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Implementation helper method to create a TCP stream server.
- createUdpServer(InetSocketAddress, ChannelListener<? super MulticastMessageChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a UDP server.
- createUdpServer(InetSocketAddress, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a UDP server.
- createWorker() - Method in interface org.xnio.XnioWorkerConfigurator
-
Create the worker, returning
null
if no worker is available. - createWorker(ThreadGroup, OptionMap) - Method in class org.xnio.Xnio
-
Construct a new XNIO worker.
- createWorker(ThreadGroup, OptionMap, Runnable) - Method in class org.xnio.Xnio
-
Construct a new XNIO worker.
- createWorker(OptionMap) - Method in class org.xnio.Xnio
-
Construct a new XNIO worker.
- createWorkerBuilder() - Method in class org.xnio.Xnio
-
Create a new worker builder.
- currentThread() - Static method in class org.xnio.XnioIoThread
-
Get the current XNIO thread.
D
- debugString(ByteBuffer) - Static method in class org.xnio.Buffers
-
Get a debug-friendly description of the buffer.
- debugString(ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Get a debug-friendly description of the buffer.
- DEFLATE - Enum constant in enum org.xnio.CompressionType
-
ZLIB compatible compression.
- deflaterState() - Method in class org.xnio._private.Messages_$logger
- deflaterState() - Method in interface org.xnio._private.Messages
- deflaterState$str() - Method in class org.xnio._private.Messages_$logger
- DeflatingStreamSinkConduit - Class in org.xnio.conduits
-
A filtering stream sink conduit which compresses the written data.
- DeflatingStreamSinkConduit(StreamSinkConduit, Deflater) - Constructor for class org.xnio.conduits.DeflatingStreamSinkConduit
-
Construct a new instance.
- delegate - Variable in class org.xnio.AbstractConvertingIoFuture
-
The delegate future result.
- delegatingChannelListener(ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
A delegating channel listener which passes an event to another listener of the same or a super type.
- delegatingChannelListener(T, ChannelListener.SimpleSetter<T>) - Static method in class org.xnio.ChannelListeners
-
A delegating channel listener which passes an event to the listener stored in the given setter.
- DelegatingChannelListener<T> - Class in org.xnio
-
A base class for a channel listener which performs an action and then calls a delegate listener.
- DelegatingChannelListener(ChannelListener<? super T>) - Constructor for class org.xnio.DelegatingChannelListener
-
Construct a new instance.
- differentWorkers() - Method in class org.xnio._private.Messages_$logger
- differentWorkers() - Method in interface org.xnio._private.Messages
- differentWorkers$str() - Method in class org.xnio._private.Messages_$logger
- DIRECT - Static variable in class org.xnio.ByteBufferPool.Set
-
The direct buffer source set.
- DIRECT - Static variable in interface org.xnio.Pool
-
Deprecated.A compatibility pool which maps to
ByteBufferPool.MEDIUM_DIRECT
. - DIRECT_BYTE_BUFFER_ALLOCATOR - Static variable in interface org.xnio.BufferAllocator
-
A simple allocator for direct byte buffers.
- directExecutor() - Static method in class org.xnio.IoUtils
-
Get the direct executor.
- discard() - Method in interface org.xnio.Pooled
-
Deprecated.Discard this resource.
- DONE - Enum constant in enum org.xnio.IoFuture.Status
-
The operation has completed successfully.
- drain(FileChannel, long, long) - Static method in class org.xnio.channels.Channels
-
Attempt to drain the given number of bytes from the file channel.
- drain(ReadableByteChannel, long) - Static method in class org.xnio.channels.Channels
-
Attempt to drain the given number of bytes from the readable byte channel.
- drain(StreamSourceChannel, long) - Static method in class org.xnio.channels.Channels
-
Attempt to drain the given number of bytes from the stream source channel.
- drain(StreamSourceConduit, long) - Static method in class org.xnio.conduits.Conduits
-
Attempt to drain the given number of bytes from the stream source conduit.
- drainListener(long, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
Create a channel listener which automatically drains the given number of bytes from the channel and then calls a listener.
- dump(ByteBuffer, Appendable, int, int) - Static method in class org.xnio.Buffers
-
Dump a byte buffer to the given target.
- dump(CharBuffer, Appendable, int, int) - Static method in class org.xnio.Buffers
-
Dump a character buffer to the given target.
E
- empty() - Static method in class org.xnio.Sequence
-
Return an empty sequence.
- EMPTY - Static variable in interface org.xnio.channels.Configurable
-
An empty configurable instance.
- EMPTY - Static variable in class org.xnio.OptionMap
-
The empty option map.
- EMPTY_BYTE_BUFFER - Static variable in class org.xnio.Buffers
-
The empty byte buffer.
- EMPTY_BYTES - Static variable in class org.xnio.sasl.SaslUtils
-
A zero-length byte array, useful for sending and receiving empty SASL messages.
- EMPTY_POOLED_BYTE_BUFFER - Static variable in class org.xnio.Buffers
-
The empty pooled byte buffer.
- emptyPooledByteBuffer() - Static method in class org.xnio.Buffers
-
Create a "pooled" empty buffer.
- EmptyStreamSourceChannel - Class in org.xnio.channels
-
A stream source channel which is always empty.
- EmptyStreamSourceChannel(XnioIoThread) - Constructor for class org.xnio.channels.EmptyStreamSourceChannel
-
Construct a new instance.
- EmptyStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which is always empty.
- EmptyStreamSourceConduit(XnioIoThread) - Constructor for class org.xnio.conduits.EmptyStreamSourceConduit
-
Construct a new instance.
- emptyToStream(OutputStream, ByteBuffer) - Static method in class org.xnio.Buffers
-
Empty a buffer to an output stream.
- endsWith(char) - Method in class org.xnio.ByteString
- endsWith(String) - Method in class org.xnio.ByteString
- endsWith(ByteString) - Method in class org.xnio.ByteString
- endsWithIgnoreCase(char) - Method in class org.xnio.ByteString
- endsWithIgnoreCase(String) - Method in class org.xnio.ByteString
- endsWithIgnoreCase(ByteString) - Method in class org.xnio.ByteString
- enqueue() - Method in class org.xnio.AutomaticReference
-
Deprecated.Not supported.
- equals(Object) - Method in class org.xnio.ByteString
-
Determine if this ByteString equals another ByteString.
- equals(Object) - Method in class org.xnio.OptionMap
-
Determine whether this option map is equal to another.
- equals(Object) - Method in class org.xnio.Property
-
Determine if this Property equals another Property.
- equals(Object) - Method in class org.xnio.Sequence
-
Determine whether this sequence is equal to another.
- equals(ByteString) - Method in class org.xnio.ByteString
-
Determine if this ByteString equals another ByteString.
- equals(OptionMap) - Method in class org.xnio.OptionMap
-
Determine whether this option map is equal to another.
- equals(Property) - Method in class org.xnio.Property
-
Determine if this Property equals another Property.
- equals(Sequence<?>) - Method in class org.xnio.Sequence
-
Determine whether this sequence is equal to another.
- equalsIgnoreCase(ByteString) - Method in class org.xnio.ByteString
-
Determine if this ByteString equals another ByteString, ignoring case (ASCII).
- equalToString(String) - Method in class org.xnio.ByteString
-
Determine whether this
ByteString
is equal (case-sensitively) to the givenString
. - equalToStringIgnoreCase(String) - Method in class org.xnio.ByteString
-
Determine whether this
ByteString
is equal (case-insensitively) to the givenString
. - evaluateChallenge(SaslClient, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Evaluate a sasl challenge.
- evaluateChallenge(SaslClient, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Evaluate a sasl challenge.
- evaluateResponse(SaslServer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Evaluate a sasl response.
- evaluateResponse(SaslServer, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Evaluate a sasl response.
- exceptionHandlerException(Throwable) - Method in class org.xnio._private.Messages_$logger
- exceptionHandlerException(Throwable) - Method in interface org.xnio._private.Messages
- exceptionHandlerException$str() - Method in class org.xnio._private.Messages_$logger
- execute(Runnable) - Method in interface org.xnio.XnioExecutor
-
Execute a task in this executor.
- execute(Runnable) - Method in class org.xnio.XnioWorker
-
Execute a command in the task pool.
- executeAfter(Runnable, long, TimeUnit) - Method in interface org.xnio.XnioExecutor
-
Execute a command after a period of time.
- executeAtInterval(Runnable, long, TimeUnit) - Method in interface org.xnio.XnioExecutor
-
Execute a command repeatedly at a time interval until it is cancelled.
- executorChannelListener(ChannelListener<T>, Executor) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which executes a delegate channel listener via an executor.
- executorSubmitFailed(RejectedExecutionException, Channel) - Method in class org.xnio._private.Messages_$logger
- executorSubmitFailed(RejectedExecutionException, Channel) - Method in interface org.xnio._private.Messages
- executorSubmitFailed$str() - Method in class org.xnio._private.Messages_$logger
- expandedSslBufferEnabled(int) - Method in class org.xnio._private.Messages_$logger
- expandedSslBufferEnabled(int) - Method in interface org.xnio._private.Messages
- expandedSslBufferEnabled$str() - Method in class org.xnio._private.Messages_$logger
- ExtendedHandshakeChecker - Interface in org.xnio.http
-
A class that can decide if a HTTP upgrade handshake is valid.
- extraChallenge() - Method in class org.xnio._private.Messages_$logger
- extraChallenge() - Method in interface org.xnio._private.Messages
- extraChallenge$str() - Method in class org.xnio._private.Messages_$logger
- extraResponse() - Method in class org.xnio._private.Messages_$logger
- extraResponse() - Method in interface org.xnio._private.Messages
- extraResponse$str() - Method in class org.xnio._private.Messages_$logger
F
- FAILED - Enum constant in enum org.xnio.IoFuture.Status
-
The operation did not succeed.
- FailedIoFuture<T> - Class in org.xnio
-
An implementation of
IoFuture
that represents an immediately-failed operation. - FailedIoFuture(IOException) - Constructor for class org.xnio.FailedIoFuture
-
Create an instance.
- failedToCloseSSLEngine(Throwable, Exception) - Method in class org.xnio._private.Messages_$logger
- failedToCloseSSLEngine(Throwable, Exception) - Method in interface org.xnio._private.Messages
- failedToCloseSSLEngine$str() - Method in class org.xnio._private.Messages_$logger
- failedToInvokeFileWatchCallback(Throwable) - Method in class org.xnio._private.Messages_$logger
- failedToInvokeFileWatchCallback(Throwable) - Method in interface org.xnio._private.Messages
- failedToInvokeFileWatchCallback$str() - Method in class org.xnio._private.Messages_$logger
- fieldNotAccessible(String, Class<?>) - Method in class org.xnio._private.Messages_$logger
- fieldNotAccessible(String, Class<?>) - Method in interface org.xnio._private.Messages
- fieldNotAccessible$str() - Method in class org.xnio._private.Messages_$logger
- fieldNotStatic(String, Class<?>) - Method in class org.xnio._private.Messages_$logger
- fieldNotStatic(String, Class<?>) - Method in interface org.xnio._private.Messages
- fieldNotStatic$str() - Method in class org.xnio._private.Messages_$logger
- FILE_ACCESS - Static variable in class org.xnio.Options
-
The file access mode to use when opening a file.
- FILE_APPEND - Static variable in class org.xnio.Options
-
A flag which indicates that opened files should be appended to.
- FILE_CREATE - Static variable in class org.xnio.Options
-
A flag which indicates that a file should be created if it does not exist (
true
by default for writing files,false
by default for reading files). - FileAccess - Enum in org.xnio
-
Possible file access modes.
- FileChangeCallback - Interface in org.xnio
-
Callback for file system change events
- FileChangeEvent - Class in org.xnio
-
The event object that is fired when a file system change is detected.
- FileChangeEvent(File, FileChangeEvent.Type) - Constructor for class org.xnio.FileChangeEvent
-
Construct a new instance.
- FileChangeEvent.Type - Enum in org.xnio
-
Watched file event types.
- FileChannel - Class in java.nio.channels
-
Compatibility stub.
- FileChannel() - Constructor for class java.nio.channels.FileChannel
- FileChannel.MapMode - Class in java.nio.channels
- fileReceivingChannelListener(FileChannel, long, long, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A file-receiving channel listener.
- fileSendingChannelListener(FileChannel, long, long, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A file-sending channel listener.
- FileSystemWatcher - Interface in org.xnio
-
File system watcher service.
- fill(ByteBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(CharBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(IntBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(LongBuffer, long, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(ShortBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fillFromStream(ByteBuffer, InputStream) - Static method in class org.xnio.Buffers
-
Fill a buffer from an input stream.
- FinishedIoFuture<T> - Class in org.xnio
-
An implementation of
IoFuture
that represents an immediately-successful operation. - FinishedIoFuture(T) - Constructor for class org.xnio.FinishedIoFuture
-
Create an instance.
- FixedLengthOverflowException - Exception Class in org.xnio.channels
-
Exception thrown when a fixed-length write channel is written beyond its full length.
- FixedLengthOverflowException() - Constructor for exception class org.xnio.channels.FixedLengthOverflowException
-
Constructs a
FixedLengthOverflowException
with no detail message. - FixedLengthOverflowException(String) - Constructor for exception class org.xnio.channels.FixedLengthOverflowException
-
Constructs a
FixedLengthOverflowException
with the specified detail message. - FixedLengthOverflowException(String, Throwable) - Constructor for exception class org.xnio.channels.FixedLengthOverflowException
-
Constructs a
FixedLengthOverflowException
with the specified detail message and cause. - FixedLengthOverflowException(Throwable) - Constructor for exception class org.xnio.channels.FixedLengthOverflowException
-
Constructs a
FixedLengthOverflowException
with the specified cause. - FixedLengthStreamSinkChannel - Class in org.xnio.channels
-
A channel which writes a fixed amount of data.
- FixedLengthStreamSinkChannel(StreamSinkChannel, long, boolean, boolean, ChannelListener<? super FixedLengthStreamSinkChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSinkChannel
-
Construct a new instance.
- FixedLengthStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit with a limited length.
- FixedLengthStreamSinkConduit(FixedLengthStreamSinkConduit) - Constructor for class org.xnio.conduits.FixedLengthStreamSinkConduit
-
Construct a new instance.
- FixedLengthStreamSourceChannel - Class in org.xnio.channels
-
A channel which reads data of a fixed length and calls a finish listener.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, boolean, boolean, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, boolean, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which limits the length of input.
- FixedLengthStreamSourceConduit(StreamSourceConduit, long) - Constructor for class org.xnio.conduits.FixedLengthStreamSourceConduit
-
Construct a new instance.
- FixedLengthUnderflowException - Exception Class in org.xnio.channels
-
Exception thrown when a fixed-length write channel is not written to its full length.
- FixedLengthUnderflowException() - Constructor for exception class org.xnio.channels.FixedLengthUnderflowException
-
Constructs a
UnfinishedWriteException
with no detail message. - FixedLengthUnderflowException(String) - Constructor for exception class org.xnio.channels.FixedLengthUnderflowException
-
Constructs a
UnfinishedWriteException
with the specified detail message. - FixedLengthUnderflowException(String, Throwable) - Constructor for exception class org.xnio.channels.FixedLengthUnderflowException
-
Constructs a
UnfinishedWriteException
with the specified detail message and cause. - FixedLengthUnderflowException(Throwable) - Constructor for exception class org.xnio.channels.FixedLengthUnderflowException
-
Constructs a
UnfinishedWriteException
with the specified cause. - fixedOverflow() - Method in class org.xnio._private.Messages_$logger
- fixedOverflow() - Method in interface org.xnio._private.Messages
- fixedOverflow$str() - Method in class org.xnio._private.Messages_$logger
- fixedUnderflow(long) - Method in class org.xnio._private.Messages_$logger
- fixedUnderflow(long) - Method in interface org.xnio._private.Messages
- fixedUnderflow$str() - Method in class org.xnio._private.Messages_$logger
- flip(T) - Static method in class org.xnio.Buffers
-
Flip a buffer.
- flush() - Method in class org.xnio.channels.AssembledMessageChannel
- flush() - Method in class org.xnio.channels.AssembledStreamChannel
- flush() - Method in class org.xnio.channels.BlockingByteChannel
- flush() - Method in class org.xnio.channels.BlockingWritableByteChannel
- flush() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- flush() - Method in class org.xnio.channels.NullStreamSinkChannel
- flush() - Method in class org.xnio.channels.SplitStreamSinkChannel
- flush() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Flush any waiting partial send or write.
- flush() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Perform channel flush.
- flush() - Method in class org.xnio.conduits.AbstractSinkConduit
- flush() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- flush() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- flush() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- flush() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- flush() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- flush() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- flush() - Method in class org.xnio.conduits.FramingMessageSinkConduit
- flush() - Method in class org.xnio.conduits.NullStreamSinkConduit
- flush() - Method in interface org.xnio.conduits.SinkConduit
-
Flush out any unwritten, buffered output.
- flush() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- flush() - Method in class org.xnio.sasl.SaslUnwrappingConduit
- flush() - Method in class org.xnio.sasl.SaslWrappingConduit
- flush() - Method in interface org.xnio.streams.BufferPipeOutputStream.BufferWriter
-
Flushes this stream by writing any buffered output to the underlying stream.
- flush() - Method in class org.xnio.streams.BufferPipeOutputStream
- flush() - Method in class org.xnio.streams.ChannelOutputStream
- flush() - Method in class org.xnio.streams.LimitedOutputStream
- flush() - Method in class org.xnio.streams.WriterOutputStream
- flushAction(boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- flushAction(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.The action to perform when the channel is flushed.
- flushAllCaches() - Static method in class org.xnio.ByteBufferPool
-
Flush all thread-local caches for all buffer sizes.
- flushBlocking(SuspendableWriteChannel) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking flush on a writable channel.
- flushBlocking(SuspendableWriteChannel, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking flush on a writable channel.
- flushCaches() - Method in class org.xnio.ByteBufferPool
-
Flush thread-local caches.
- flushingChannelListener(ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A flushing channel listener.
- flushSmallBuffer() - Method in class org.xnio._private.Messages_$logger
- flushSmallBuffer() - Method in interface org.xnio._private.Messages
- flushSmallBuffer$str() - Method in class org.xnio._private.Messages_$logger
- force(boolean) - Method in class java.nio.channels.FileChannel
- forceTermination() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
- forceTermination() - Method in class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
- forceTermination() - Method in interface org.xnio.conduits.TerminateHandler
-
Force the front-end channel to close, in response to XNIO worker shutdown.
- forceTermination() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
- FramedMessageChannel - Class in org.xnio.channels
-
Deprecated.This class is deprecated; use conduits instead.
- FramedMessageChannel(ConnectedStreamChannel, ByteBuffer, ByteBuffer) - Constructor for class org.xnio.channels.FramedMessageChannel
-
Deprecated.Construct a new instance.
- FramedMessageChannel(ConnectedStreamChannel, Pooled<ByteBuffer>, Pooled<ByteBuffer>) - Constructor for class org.xnio.channels.FramedMessageChannel
-
Deprecated.Construct a new instance.
- FramingMessageSinkConduit - Class in org.xnio.conduits
-
A message sink conduit which implements a simple message framing protocol over a stream conduit.
- FramingMessageSinkConduit(StreamSinkConduit, boolean, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.FramingMessageSinkConduit
-
Construct a new instance.
- FramingMessageSourceConduit - Class in org.xnio.conduits
-
A message source conduit which implements a simple message framing protocol over a stream conduit.
- FramingMessageSourceConduit(StreamSourceConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.FramingMessageSourceConduit
-
Construct a new instance.
- free() - Method in class org.xnio.AutomaticReference
-
Deprecated.Free this reference.
- free() - Method in interface org.xnio.Pooled
-
Deprecated.Free this resource for immediate re-use.
- free(ByteBuffer) - Static method in class org.xnio.ByteBufferPool
-
Free a buffer into its appropriate pool based on its size.
- free(ByteBuffer[], int, int) - Static method in class org.xnio.ByteBufferPool
-
Bulk-free buffers from an array as with
ByteBufferPool.free(ByteBuffer)
. - fromInt(int) - Static method in class org.xnio.ByteString
-
Get a string version of the given value.
- fromLong(long) - Static method in class org.xnio.ByteString
-
Get a string version of the given value.
- fromString(String) - Static method in enum org.xnio.sasl.SaslQop
-
Get the SASL QOP level for the given string.
- fromString(String) - Static method in enum org.xnio.sasl.SaslStrength
-
Get the SASL Strength level for the given string.
- fromString(String, ClassLoader) - Static method in class org.xnio.Option
-
Get an option from a string name, using the given classloader.
- futureMsg - Static variable in interface org.xnio._private.Messages
- FutureResult<T> - Class in org.xnio
-
A result with a corresponding
IoFuture
instance. - FutureResult() - Constructor for class org.xnio.FutureResult
-
Construct a new instance.
- FutureResult(Executor) - Constructor for class org.xnio.FutureResult
-
Construct a new instance.
G
- get() - Method in class org.xnio.AbstractConvertingIoFuture
- get() - Method in class org.xnio.AbstractIoFuture
-
Get the result of the operation.
- get() - Method in class org.xnio.AutomaticReference
-
Deprecated.Always returns
null
. - get() - Method in class org.xnio.ChannelListener.SimpleSetter
-
Get the channel listener set on this setter.
- get() - Method in class org.xnio.FinishedIoFuture
- get() - Method in interface org.xnio.IoFuture
-
Get the result of the operation.
- get(int) - Method in class org.xnio.Sequence
-
Get the value at a certain index.
- get(Option<Boolean>, boolean) - Method in class org.xnio.OptionMap
-
Get a boolean value from this option map, with a specified default if the value is missing.
- get(Option<Integer>, int) - Method in class org.xnio.OptionMap
-
Get a int value from this option map, with a specified default if the value is missing.
- get(Option<Long>, long) - Method in class org.xnio.OptionMap
-
Get a long value from this option map, with a specified default if the value is missing.
- get(Option<T>) - Method in class org.xnio.OptionMap
-
Get the value of an option from this option map.
- get(Option<T>, T) - Method in class org.xnio.OptionMap
-
Get the value of an option from this option map, with a specified default if the value is missing.
- getAcceptListener() - Method in interface org.xnio.channels.AcceptListenerSettable
-
Get the accept listener.
- getAcceptSetter() - Method in interface org.xnio.channels.AcceptingChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptSetter() - Method in interface org.xnio.channels.SimpleAcceptingChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptSetter() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptThread() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Deprecated.The
SuspendableAcceptChannel.getIoThread()
method should be used instead. - getBindAddress() - Method in interface org.xnio.management.XnioServerMXBean
-
Get the bind address.
- getBindAddress(InetAddress) - Method in class org.xnio.XnioWorker
-
Get the expected bind address for the given destination, if any.
- getBindAddressConfigurations() - Method in class org.xnio.XnioWorker.Builder
- getBindAddressTable() - Method in class org.xnio.XnioWorker
-
Get the bind address table.
- getBuffer(boolean) - Method in interface org.xnio.streams.BufferPipeOutputStream.BufferWriter
-
Get a new buffer to be filled.
- getBufferSize() - Method in class org.xnio.ByteBufferSlicePool
-
Deprecated.Return the size of the
ByteBuffer
s that are returned byByteBufferSlicePool.allocate()
. - getBusyWorkerThreadCount() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get an estimate of the number of busy threads in the worker pool.
- getBusyWorkerThreadCount() - Method in class org.xnio.XnioWorker
-
Get an estimate of the number of busy threads in the worker pool.
- getBytes() - Method in class org.xnio.ByteString
-
Get a copy of the bytes of this ByteString.
- getBytes(byte[]) - Method in class org.xnio.ByteString
-
Deprecated.Replaced by
ByteString.copyTo(byte[])
. - getBytes(byte[], int) - Method in class org.xnio.ByteString
-
Deprecated.Replaced by
ByteString.copyTo(byte[],int)
. - getBytes(byte[], int, int) - Method in class org.xnio.ByteString
-
Deprecated.Replaced by
ByteString.copyTo(byte[],int,int)
. - getBytes(String) - Static method in class org.xnio.ByteString
-
Get a byte string from the bytes of the character string.
- getBytes(String, String) - Static method in class org.xnio.ByteString
-
Get a byte string from the bytes of a character string.
- getBytes(String, Charset) - Static method in class org.xnio.ByteString
-
Get a byte string from the bytes of a character string.
- getBytes(ByteBuffer) - Static method in class org.xnio.ByteString
-
Get a byte string from all remaining bytes of a ByteBuffer.
- getBytes(ByteBuffer, int) - Static method in class org.xnio.ByteString
-
Get a byte string from a ByteBuffer.
- getChannel() - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Get the underlying channel.
- getChannel() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Return the channel associated with this key.
- getChannel() - Method in class org.xnio.channels.PushBackStreamChannel
- getChannel() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the channel which is wrapped by this object.
- getChannel() - Method in interface org.xnio.channels.WrappedChannel
-
Get the channel which is wrapped by this object.
- getChannel(Object) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getChannel(Object) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getChannel(Object) - Method in interface org.xnio.channels.ProtectedWrappedChannel
-
Get the channel which is wrapped by this object, or
null
if the guard is invalid. - getChannelListenerTask(T, ChannelListener.SimpleSetter<T>) - Static method in class org.xnio.ChannelListeners
-
Get a task which invokes the given channel listener on the given channel via its setter.
- getChannelListenerTask(T, ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
Get a task which invokes the given channel listener on the given channel.
- getCloseListener() - Method in interface org.xnio.channels.CloseListenerSettable
-
Get the close listener.
- getCloseListener() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getCloseListener() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getCloseListener() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getCloseListener() - Method in class org.xnio.channels.NullStreamSinkChannel
- getCloseListener() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getCloseListener() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getCloseListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getCloseListener() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getCloseListener() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getCloseListener() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getCloseListener() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getCloseListener() - Method in class org.xnio.MessageConnection
- getCloseListener() - Method in class org.xnio.StreamConnection
- getCloseSetter() - Method in interface org.xnio.channels.AcceptingChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.AssembledChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledMessageChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledSslChannel
- getCloseSetter() - Method in class org.xnio.channels.AssembledStreamChannel
- getCloseSetter() - Method in interface org.xnio.channels.BoundChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.CloseableChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getCloseSetter() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getCloseSetter() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getCloseSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.NullStreamSinkChannel
- getCloseSetter() - Method in class org.xnio.channels.PushBackStreamChannel
- getCloseSetter() - Method in interface org.xnio.channels.ReadableMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SimpleAcceptingChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getCloseSetter() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getCloseSetter() - Method in interface org.xnio.channels.SslChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamSinkChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamSourceChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.WritableMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getCloseSetter() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getCloseSetter() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getCloseSetter() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getCloseSetter() - Method in class org.xnio.MessageConnection
- getCloseSetter() - Method in class org.xnio.ssl.SslConnection
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.StreamConnection
- getConduit() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Get the underlying conduit for this channel.
- getConnectionCount() - Method in interface org.xnio.management.XnioServerMXBean
-
Get an estimate of the current connection count.
- getConnectionLimitHighWater() - Method in interface org.xnio.management.XnioServerMXBean
-
Get the connection limit high-water mark.
- getConnectionLimitLowWater() - Method in interface org.xnio.management.XnioServerMXBean
-
Get the connection limit low-water mark.
- getContextManager() - Static method in class org.xnio.XnioWorker
-
Get the context manager for XNIO workers.
- getCoreWorkerPoolSize() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get the core worker thread pool size.
- getCoreWorkerPoolSize() - Method in class org.xnio.XnioWorker.Builder
- getCoreWorkerPoolSize() - Method in class org.xnio.XnioWorker
-
Get the core worker pool size.
- getDeflatingChannel(StreamSinkChannel, Deflater) - Method in class org.xnio.XnioWorker
-
Create a stream channel that compresses to the destination according to the configuration in the given inflater.
- getDeflatingChannel(StreamSinkChannel, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream channel that compresses to the destination according to the configuration in the given option map.
- getDelegate() - Method in class org.xnio.AbstractConvertingIoFuture
- getDelegatingSetter(ChannelListener.Setter<? extends Channel>, T) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener setter which delegates to the given target setter with a different channel type.
- getDestinationAddress() - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the destination address.
- getDestinationAddress(Class<A>) - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the destination address.
- getEngine() - Method in class org.xnio.ssl.JsseSslConnection
- getException() - Method in class org.xnio.AbstractConvertingIoFuture
- getException() - Method in class org.xnio.AbstractIoFuture
-
Get the failure reason.
- getException() - Method in class org.xnio.FinishedIoFuture
- getException() - Method in interface org.xnio.IoFuture
-
Get the failure reason.
- getExternalExecutorService() - Method in class org.xnio.XnioWorker.Builder
- getFile() - Method in class org.xnio.FileChangeEvent
-
Get the file which was being watched.
- getFuture(IoFuture<T>) - Static method in class org.xnio.IoUtils
-
Get a
java.util.concurrent
-styleFuture
instance wrapper for anIoFuture
instance. - getGroup() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Return the multicast group for which this key was created.
- getHandshakeSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- getHandshakeSetter() - Method in class org.xnio.channels.AssembledSslChannel
- getHandshakeSetter() - Method in interface org.xnio.channels.SslChannel
-
Get the setter which can be used to change the handshake listener for this channel.
- getHandshakeSetter() - Method in class org.xnio.ssl.JsseSslConnection
- getHandshakeSetter() - Method in class org.xnio.ssl.JsseSslStreamConnection
- getHandshakeSetter() - Method in class org.xnio.ssl.SslConnection
-
Get the setter which can be used to change the handshake listener for this channel.
- getIn() - Method in class org.xnio.streams.Pipe
-
Get the input (read) side of the pipe.
- getInflatingChannel(StreamSourceChannel, Inflater) - Method in class org.xnio.XnioWorker
-
Create a stream channel that decompresses the source data according to the configuration in the given inflater.
- getInflatingChannel(StreamSourceChannel, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream channel that decompresses the source data according to the configuration in the given option map.
- getInstance() - Static method in class org.xnio.Xnio
-
Get an XNIO provider instance from XNIO's class loader.
- getInstance() - Method in interface org.xnio.XnioProvider
-
Get the XNIO instance for this provider.
- getInstance(ClassLoader) - Static method in class org.xnio.Xnio
-
Get an XNIO provider instance.
- getInstance(String) - Static method in class org.xnio.Xnio
-
Get a specific XNIO provider instance from XNIO's class loader.
- getInstance(String, ClassLoader) - Static method in class org.xnio.Xnio
-
Get a specific XNIO provider instance.
- getInstanceContextManager() - Method in class org.xnio.XnioWorker
-
Get the instance context manager for XNIO workers by delegating to
XnioWorker.getContextManager()
. - getInterruptibly() - Method in class org.xnio.AbstractConvertingIoFuture
- getInterruptibly() - Method in class org.xnio.AbstractIoFuture
-
Get the result of the operation.
- getInterruptibly() - Method in class org.xnio.FinishedIoFuture
- getInterruptibly() - Method in interface org.xnio.IoFuture
-
Get the result of the operation.
- getIoFuture() - Method in class org.xnio.FutureResult
-
Get the
IoFuture
for this manager. - getIoThread() - Method in class org.xnio.channels.AssembledChannel
- getIoThread() - Method in class org.xnio.channels.AssembledMessageChannel
- getIoThread() - Method in class org.xnio.channels.AssembledStreamChannel
- getIoThread() - Method in interface org.xnio.channels.CloseableChannel
-
Get the I/O thread associated with this channel.
- getIoThread() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getIoThread() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getIoThread() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getIoThread() - Method in class org.xnio.channels.NullStreamSinkChannel
- getIoThread() - Method in class org.xnio.channels.PushBackStreamChannel
- getIoThread() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getIoThread() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getIoThread() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Get an accept thread for this channel.
- getIoThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the I/O thread associated with this channel.
- getIoThread() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getIoThread() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getIoThread() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getIoThread() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getIoThread() - Method in class org.xnio.Connection
- getIoThread() - Method in class org.xnio.XnioWorker
-
Get an I/O thread from this worker.
- getIoThread(int) - Method in class org.xnio.XnioWorker
-
Get an I/O thread from this worker.
- getIoThreadCount() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get the I/O thread count.
- getIoThreadCount() - Method in class org.xnio.XnioWorker
-
Get the number of I/O threads configured on this worker.
- getJarName() - Static method in class org.xnio.Version
-
Get the name of the program JAR.
- getKey() - Method in class org.xnio.Property
-
Get the key of this key/value Property.
- getLarge() - Method in class org.xnio.ByteBufferPool.Set
-
Get the large buffer pool for this set.
- getLeftSide() - Method in class org.xnio.ChannelPipe
-
Get the pipe source.
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedChannel
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getLocalAddress() - Method in interface org.xnio.channels.BoundChannel
-
Get the local address that this channel is bound to.
- getLocalAddress() - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Get the local address that this channel is bound to.
- getLocalAddress() - Method in class org.xnio.ssl.JsseSslConnection
- getLocalAddress() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Get the local address that this channel is bound to.
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedChannel
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getLocalAddress(Class<A>) - Method in interface org.xnio.channels.BoundChannel
-
Get the local address of a given type, or
null
if the address is not of that type. - getLocalAddress(Class<A>) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Get the local address of a given type, or
null
if the address is not of that type. - getLocalAddress(Class<A>) - Method in class org.xnio.Connection
- getLocation() - Method in exception class org.xnio.http.RedirectException
-
Get the redirection target location.
- getLoggingLocale() - Method in class org.xnio._private.Messages_$logger
- getManagerNotifier() - Static method in class org.xnio.IoUtils
-
Get a notifier which forwards the result to another
IoFuture
's manager. - getMap() - Method in class org.xnio.OptionMap.Builder
-
Build a map that reflects the current state of this builder.
- getMaxWorkerPoolSize() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get the maximum worker thread pool size.
- getMaxWorkerPoolSize() - Method in class org.xnio.XnioWorker.Builder
- getMaxWorkerPoolSize() - Method in class org.xnio.XnioWorker
-
Get the maximum worker pool size.
- getModifiedUtf8(ByteBuffer) - Static method in class org.xnio.Buffers
-
Get a modified UTF-8 string from the remainder of the buffer.
- getModifiedUtf8Z(ByteBuffer) - Static method in class org.xnio.Buffers
-
Get a 0-terminated string from the byte buffer, decoding it using "modified UTF-8" encoding.
- getMXBean() - Method in class org.xnio.XnioWorker
- getName() - Method in class org.xnio.LocalSocketAddress
-
Get the name (filesystem path) of this local socket address.
- getName() - Method in interface org.xnio.management.XnioProviderMXBean
-
Get the provider name.
- getName() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get the worker's name.
- getName() - Method in class org.xnio.Option
-
Get the name of this option.
- getName() - Method in class org.xnio.Xnio
-
Get the name of this XNIO provider.
- getName() - Method in interface org.xnio.XnioProvider
-
Get the provider name.
- getName() - Method in class org.xnio.XnioWorker
-
Get the name of this worker.
- getNetworkInterface() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Return the network interface for which this key was created.
- getNormal() - Method in class org.xnio.ByteBufferPool.Set
-
Get the medium buffer pool for this set.
- getNotifierExecutor() - Method in class org.xnio.AbstractIoFuture
-
Get the executor used to run asynchronous notifiers.
- getNumber() - Method in class org.xnio.XnioIoThread
-
Get the number of this thread.
- getOption(Configurable, Option<Boolean>, boolean) - Static method in class org.xnio.channels.Channels
-
Get an option value from a configurable target.
- getOption(Configurable, Option<Integer>, int) - Static method in class org.xnio.channels.Channels
-
Get an option value from a configurable target.
- getOption(Configurable, Option<Long>, long) - Static method in class org.xnio.channels.Channels
-
Get an option value from a configurable target.
- getOption(Configurable, Option<T>, T) - Static method in class org.xnio.channels.Channels
-
Get an option value from a configurable target.
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledChannel
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledMessageChannel
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledStreamChannel
- getOption(Option<T>) - Method in interface org.xnio.channels.Configurable
-
Get the value of a channel option.
- getOption(Option<T>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getOption(Option<T>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getOption(Option<T>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getOption(Option<T>) - Method in class org.xnio.channels.NullStreamSinkChannel
- getOption(Option<T>) - Method in class org.xnio.channels.PushBackStreamChannel
- getOption(Option<T>) - Method in class org.xnio.channels.SplitStreamSinkChannel
- getOption(Option<T>) - Method in class org.xnio.channels.SplitStreamSourceChannel
- getOption(Option<T>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the value of a channel option.
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getOption(Option<T>) - Method in class org.xnio.Connection
- getOption(Option<T>) - Method in class org.xnio.ssl.JsseSslConnection
-
Get the value of a channel option.
- getOption(Option<T>) - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Get the value of a channel option.
- getOption(Option<T>) - Method in class org.xnio.XnioWorker
- getOut() - Method in class org.xnio.streams.Pipe
-
Get the output (write) side of the pipe.
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedChannel
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getPeerAddress() - Method in interface org.xnio.channels.ConnectedChannel
-
Get the peer address of this channel.
- getPeerAddress() - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Get the peer address of this channel.
- getPeerAddress() - Method in class org.xnio.ssl.JsseSslConnection
- getPeerAddress() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Get the peer address of this channel.
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedChannel
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getPeerAddress(Class<A>) - Method in interface org.xnio.channels.ConnectedChannel
-
Get the peer address of a given type, or
null
if the address is not of that type. - getPeerAddress(Class<A>) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Get the peer address of a given type, or
null
if the address is not of that type. - getPeerAddress(Class<A>) - Method in class org.xnio.Connection
- getPermit() - Static method in class org.xnio.AutomaticReference
-
Deprecated.Get the security authorization permit to create automatic references.
- getProperty(String) - Static method in class org.xnio.Xnio
-
Get an XNIO property.
- getProperty(String, String) - Static method in class org.xnio.Xnio
-
Get an XNIO property.
- getProviderName() - Method in interface org.xnio.management.XnioServerMXBean
-
Get the name of the provider.
- getProviderName() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get the name of the provider.
- getReadListener() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getReadListener() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getReadListener() - Method in interface org.xnio.channels.ReadListenerSettable
-
Get the read listener.
- getReadListener() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getReadListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getReadListener() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getReadListener() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getReadSetter() - Method in class org.xnio.channels.AssembledMessageChannel
- getReadSetter() - Method in class org.xnio.channels.AssembledStreamChannel
- getReadSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getReadSetter() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getReadSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.PushBackStreamChannel
- getReadSetter() - Method in interface org.xnio.channels.ReadableMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getReadSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.StreamSourceChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getReadSetter() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getReadThread() - Method in class org.xnio.channels.AssembledMessageChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.AssembledStreamChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.PushBackStreamChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Deprecated.The
CloseableChannel.getIoThread()
method should be used instead. - getReadThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.AbstractSourceConduit
- getReadThread() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- getReadThread() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- getReadThread() - Method in interface org.xnio.conduits.SourceConduit
-
Get the XNIO read thread.
- getReadThread() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- getReadTimeout(TimeUnit) - Method in class org.xnio.streams.BufferedChannelInputStream
-
Get the read timeout.
- getReadTimeout(TimeUnit) - Method in class org.xnio.streams.ChannelInputStream
-
Get the read timeout.
- getRemaining() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
Get the number of remaining bytes in this fixed length channel.
- getRemaining() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
Get the number of remaining bytes.
- getRemaining() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
Get the number of remaining bytes available to read.
- getRemaining() - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
Get the number of bytes which remain available to read.
- getResource() - Method in interface org.xnio.Pooled
-
Deprecated.Get the pooled resource.
- getRetryingChannelSource(ChannelSource<T>, int) - Static method in class org.xnio.IoUtils
-
A channel source which tries to acquire a channel from a delegate channel source the given number of times before giving up.
- getRightSide() - Method in class org.xnio.ChannelPipe
-
Get the pipe sink.
- getSaslClientFactories() - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered
SaslClientFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslClientFactories(ClassLoader, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered
SaslClientFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslServerFactories() - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered
SaslServerFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslServerFactories(ClassLoader, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered
SaslServerFactory
s where the order is based on the order of the Provider registration and/or class path order. - getServerMXBeans() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get servers that are opened under this worker.
- getSetter(C, AtomicReferenceFieldUpdater<C, ChannelListener>) - Static method in class org.xnio.ChannelListeners
-
Deprecated.Not recommended as a security manager will enforce unreasonable restrictions on the updater.
- getSetter(AtomicReference<ChannelListener<? super T>>) - Static method in class org.xnio.ChannelListeners
-
Get a setter based on an atomic reference.
- getSinkChannel() - Method in class org.xnio.MessageConnection
-
Get the sink channel.
- getSinkChannel() - Method in class org.xnio.StreamConnection
-
Get the sink channel.
- getSize() - Method in class org.xnio.ByteBufferPool
-
Get the size of buffers returned by this source.
- getSmall() - Method in class org.xnio.ByteBufferPool.Set
-
Get the small buffer pool for this set.
- getSourceAddress() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Return the source address if this membership key is source specific, or
null
if this membership is not source specific. - getSourceAddress() - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the source address.
- getSourceAddress(Class<A>) - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the source address.
- getSourceChannel() - Method in class org.xnio.MessageConnection
-
Get the source channel.
- getSourceChannel() - Method in class org.xnio.StreamConnection
-
Get the source channel.
- getSslContext() - Method in class org.xnio.ssl.JsseXnioSsl
-
Get the JSSE SSL context for this provider instance.
- getSslEngine(SslConnection) - Static method in class org.xnio.ssl.JsseXnioSsl
-
Get the SSL engine for a given connection.
- getSslProvider(KeyManager[], TrustManager[], OptionMap) - Method in class org.xnio.Xnio
-
Get an SSL provider for this XNIO provider.
- getSslProvider(OptionMap) - Method in class org.xnio.Xnio
-
Get an SSL provider for this XNIO provider.
- getSslSession() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- getSslSession() - Method in class org.xnio.channels.AssembledSslChannel
- getSslSession() - Method in interface org.xnio.channels.SslChannel
-
Get the current
SSLSession
for this channel. - getSslSession() - Method in class org.xnio.ssl.JsseSslConnection
- getSslSession() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Get the current
SSLSession
for this channel. - getSslSession() - Method in class org.xnio.ssl.SslConnection
-
Get the current
SSLSession
for this channel. - getStatus() - Method in class org.xnio.AbstractConvertingIoFuture
- getStatus() - Method in class org.xnio.AbstractIoFuture
-
Get the current status.
- getStatus() - Method in class org.xnio.FinishedIoFuture
- getStatus() - Method in interface org.xnio.IoFuture
-
Get the current status.
- getStatusCode() - Method in exception class org.xnio.http.RedirectException
-
Get the HTTP status code.
- getString() - Method in enum org.xnio.sasl.SaslQop
-
Get the string representation of this SASL QOP value.
- getTerminationTask() - Method in class org.xnio.XnioWorker.Builder
- getTerminationTask() - Method in class org.xnio.XnioWorker
-
Get the user task to run once termination is complete.
- getThreadGroup() - Method in class org.xnio.XnioWorker.Builder
- getThreadLocalRandom() - Static method in class org.xnio.IoUtils
-
Get a thread-local RNG.
- getType() - Method in class org.xnio.FileChangeEvent
-
Get the type of event.
- getValue() - Method in class org.xnio.Property
-
Get the value of this key/value Property.
- getValue$$bridger() - Method in class org.xnio.Property
-
Get the value of this key/value Property.
- getVersion() - Method in interface org.xnio.management.XnioProviderMXBean
-
Get the provider version string.
- getVersionString() - Static method in class org.xnio.Version
-
Get the version string.
- getWithCacheEx(int, ExceptionSupplier<R, E>) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- getWorker() - Method in class org.xnio.channels.AssembledChannel
- getWorker() - Method in class org.xnio.channels.AssembledMessageChannel
- getWorker() - Method in class org.xnio.channels.AssembledStreamChannel
- getWorker() - Method in interface org.xnio.channels.CloseableChannel
-
Get the worker for this channel.
- getWorker() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- getWorker() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getWorker() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- getWorker() - Method in class org.xnio.channels.NullStreamSinkChannel
- getWorker() - Method in class org.xnio.channels.PushBackStreamChannel
- getWorker() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getWorker() - Method in class org.xnio.channels.SplitStreamSourceChannel
- getWorker() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the worker for this channel.
- getWorker() - Method in class org.xnio.conduits.AbstractConduit
- getWorker() - Method in interface org.xnio.conduits.Conduit
-
Get the XNIO worker associated with this conduit.
- getWorker() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- getWorker() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getWorker() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- getWorker() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getWorker() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- getWorker() - Method in class org.xnio.conduits.NullStreamSinkConduit
- getWorker() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- getWorker() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- getWorker() - Method in class org.xnio.Connection
- getWorker() - Method in class org.xnio.XnioIoThread
-
Get the XNIO worker associated with this thread.
- getWorkerIoThreads() - Method in class org.xnio.XnioWorker.Builder
- getWorkerKeepAlive() - Method in class org.xnio.XnioWorker.Builder
- getWorkerName() - Method in interface org.xnio.management.XnioServerMXBean
-
Get the worker's name.
- getWorkerName() - Method in class org.xnio.XnioWorker.Builder
- getWorkerPoolSize() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get an estimate of the number of threads in the worker pool.
- getWorkerPoolSize() - Method in class org.xnio.XnioWorker
-
Get an estimate of the number of threads in the worker pool.
- getWorkerQueueSize() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Get an estimate of the number of tasks in the worker queue.
- getWorkerQueueSize() - Method in class org.xnio.XnioWorker
-
Get an estimate of the number of tasks in the worker queue.
- getWorkerStackSize() - Method in class org.xnio.XnioWorker.Builder
- getWriteListener() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getWriteListener() - Method in class org.xnio.channels.NullStreamSinkChannel
- getWriteListener() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getWriteListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getWriteListener() - Method in interface org.xnio.channels.WriteListenerSettable
-
Get the write listener.
- getWriteListener() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getWriteListener() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
- getWriteSetter() - Method in class org.xnio.channels.AssembledMessageChannel
- getWriteSetter() - Method in class org.xnio.channels.AssembledStreamChannel
- getWriteSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- getWriteSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.NullStreamSinkChannel
- getWriteSetter() - Method in class org.xnio.channels.SplitStreamSinkChannel
- getWriteSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.StreamSinkChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.WritableMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- getWriteSetter() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- getWriteThread() - Method in class org.xnio.channels.AssembledMessageChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.AssembledStreamChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.NullStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Deprecated.The
CloseableChannel.getIoThread()
method should be used instead. - getWriteThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.AbstractSinkConduit
- getWriteThread() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- getWriteThread() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.NullStreamSinkConduit
- getWriteThread() - Method in interface org.xnio.conduits.SinkConduit
-
Get the write thread for this conduit.
- getWriteThread() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- getWriteTimeout(TimeUnit) - Method in class org.xnio.streams.ChannelOutputStream
-
Get the write timeout.
- getXnio() - Method in class org.xnio.XnioWorker.Builder
- getXnio() - Method in class org.xnio.XnioWorker
-
Get the XNIO provider which produced this worker.
- globalPooledWrapper(ByteBuffer) - Static method in class org.xnio.Buffers
-
Create a pooled wrapper around a buffer that was allocated via
ByteBufferPool
. - greeting(String) - Method in class org.xnio._private.Messages_$logger
- greeting(String) - Method in interface org.xnio._private.Messages
- greeting$str() - Method in class org.xnio._private.Messages_$logger
- GZIP - Enum constant in enum org.xnio.CompressionType
-
GZIP compatible compression.
H
- handleCancelled(A) - Method in class org.xnio.IoFuture.HandlingNotifier
-
Handle cancellation.
- handleChanges(Collection<FileChangeEvent>) - Method in interface org.xnio.FileChangeCallback
-
Method that is invoked when file system changes are detected.
- handleClosed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Called when the underlying channel is closed.
- handleDone(T, A) - Method in class org.xnio.IoFuture.HandlingNotifier
-
Handle completion.
- handleEvent(T) - Method in class org.xnio.ChainedChannelListener
- handleEvent(T) - Method in interface org.xnio.ChannelListener
-
Handle the event on this channel.
- handleException(T, IOException) - Method in interface org.xnio.ChannelExceptionHandler
-
Handle an exception on the channel.
- handleFailed(IOException, A) - Method in class org.xnio.IoFuture.HandlingNotifier
-
Handle failure.
- handleHandshakeFinished() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Callback method for notification of handshake finished.
- handleReadable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Called when the underlying channel is readable.
- handleThreadExit() - Method in class org.xnio.Xnio
-
Implement tasks that will be executed on thread exits if a task worker thread is initialized through
XnioWorker$WorkerThreadFactory
. - handleWritable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Called when the underlying channel is writable.
- HandlingNotifier() - Constructor for class org.xnio.IoFuture.HandlingNotifier
- HandshakeChecker - Interface in org.xnio.http
-
A class that can decide if a HTTP upgrade handshake is valid.
- hashCode() - Method in class org.xnio.ByteString
-
Get the hash code for this ByteString.
- hashCode() - Method in class org.xnio.OptionMap
-
Get the hash code for this option map.
- hashCode() - Method in class org.xnio.Property
-
Get the hash code for this Property.
- hashCode() - Method in class org.xnio.Sequence
-
Get the hash code for this sequence.
- hashCodeIgnoreCase() - Method in class org.xnio.ByteString
- hasRemaining(Buffer[]) - Static method in class org.xnio.Buffers
-
Determine whether any of the buffers has remaining data.
- hasRemaining(Buffer[], int, int) - Static method in class org.xnio.Buffers
-
Determine whether any of the buffers has remaining data.
- HEAP - Static variable in class org.xnio.ByteBufferPool.Set
-
The heap buffer source set.
- HEAP - Static variable in interface org.xnio.Pool
-
Deprecated.A compatibility pool which maps to
ByteBufferPool.MEDIUM_HEAP
. - HIGH - Enum constant in enum org.xnio.sasl.SaslStrength
-
Specify high cipher strength.
- HttpUpgrade - Class in org.xnio.http
-
Simple HTTP client that can perform a HTTP upgrade.
I
- IMMEDIATE - Static variable in interface org.xnio.XnioExecutor.Key
-
An immediate key.
- indexOf(char) - Method in class org.xnio.ByteString
-
Get the index of the given character in this string.
- indexOf(char, int) - Method in class org.xnio.ByteString
-
Get the index of the given character in this string.
- indexOf(String) - Method in class org.xnio.ByteString
- indexOf(String, int) - Method in class org.xnio.ByteString
- indexOf(ByteString) - Method in class org.xnio.ByteString
- indexOf(ByteString, int) - Method in class org.xnio.ByteString
- indexOfIgnoreCase(String) - Method in class org.xnio.ByteString
- indexOfIgnoreCase(String, int) - Method in class org.xnio.ByteString
- indexOfIgnoreCase(ByteString) - Method in class org.xnio.ByteString
- indexOfIgnoreCase(ByteString, int) - Method in class org.xnio.ByteString
- inflaterNeedsDictionary() - Method in class org.xnio._private.Messages_$logger
- inflaterNeedsDictionary() - Method in interface org.xnio._private.Messages
- inflaterNeedsDictionary$str() - Method in class org.xnio._private.Messages_$logger
- InflatingStreamSourceConduit - Class in org.xnio.conduits
-
A filtering stream source conduit which decompresses the source data.
- InflatingStreamSourceConduit(StreamSourceConduit, Inflater) - Constructor for class org.xnio.conduits.InflatingStreamSourceConduit
-
Construct a new instance.
- initiateTransfer(long, I, O, ChannelListener<? super I>, ChannelListener<? super O>, ChannelExceptionHandler<? super I>, ChannelExceptionHandler<? super O>, Pool<ByteBuffer>) - Static method in class org.xnio.ChannelListeners
-
Initiate a low-copy transfer between two stream channels.
- initiateTransfer(I, O, Pool<ByteBuffer>) - Static method in class org.xnio.ChannelListeners
-
Initiate a low-copy transfer between two stream channels.
- intBitMask(int, int) - Static method in class org.xnio.Bits
-
Get an integer bit mask consisting of 1 bits in the given range.
- interruptedIO() - Method in class org.xnio._private.Messages_$logger
- interruptedIO() - Method in interface org.xnio._private.Messages
- interruptedIO(int) - Method in class org.xnio._private.Messages_$logger
- interruptedIO(int) - Method in interface org.xnio._private.Messages
- interruptedIO$str() - Method in class org.xnio._private.Messages_$logger
- intFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 32-bit signed big-endian int value from a byte array.
- intFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 32-bit signed little-endian int value from a byte array.
- invalidNullOption(String) - Method in class org.xnio._private.Messages_$logger
- invalidNullOption(String) - Method in interface org.xnio._private.Messages
- invalidNullOption$str() - Method in class org.xnio._private.Messages_$logger
- invalidOptionInProperty(String, String, Throwable) - Method in class org.xnio._private.Messages_$logger
- invalidOptionInProperty(String, String, Throwable) - Method in interface org.xnio._private.Messages
- invalidOptionInProperty$str() - Method in class org.xnio._private.Messages_$logger
- invalidOptionName(String) - Method in class org.xnio._private.Messages_$logger
- invalidOptionName(String) - Method in interface org.xnio._private.Messages
- invalidOptionName$str() - Method in class org.xnio._private.Messages_$logger
- invalidOptionPropertyFormat(String) - Method in class org.xnio._private.Messages_$logger
- invalidOptionPropertyFormat(String) - Method in interface org.xnio._private.Messages
- invalidOptionPropertyFormat$str() - Method in class org.xnio._private.Messages_$logger
- invalidQop(String) - Method in class org.xnio._private.Messages_$logger
- invalidQop(String) - Method in interface org.xnio._private.Messages
- invalidQop$str() - Method in class org.xnio._private.Messages_$logger
- invalidStrength(String) - Method in class org.xnio._private.Messages_$logger
- invalidStrength(String) - Method in interface org.xnio._private.Messages
- invalidStrength$str() - Method in class org.xnio._private.Messages_$logger
- invalidURLScheme(String) - Method in class org.xnio._private.Messages_$logger
- invalidURLScheme(String) - Method in interface org.xnio._private.Messages
- invalidURLScheme$str() - Method in class org.xnio._private.Messages_$logger
- invokeChannelExceptionHandler(T, ChannelExceptionHandler<? super T>, IOException) - Static method in class org.xnio.ChannelListeners
-
Safely invoke a channel exception handler, logging any errors.
- invokeChannelListener(Executor, T, ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
Invoke a channel listener on a given channel, logging any errors, using the given executor.
- invokeChannelListener(T, ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
Invoke a channel listener on a given channel, logging any errors.
- IoFuture<T> - Interface in org.xnio
-
The future result of an asynchronous request.
- IoFuture.HandlingNotifier<T,
A> - Class in org.xnio -
A base notifier class that calls the designated handler method on notification.
- IoFuture.Notifier<T,
A> - Interface in org.xnio -
A notifier that handles changes in the status of an
IoFuture
. - IoFuture.Status - Enum in org.xnio
-
The current status of an asynchronous operation.
- IoUtils - Class in org.xnio
-
General I/O utility methods.
- IP_TRAFFIC_CLASS - Static variable in class org.xnio.Options
-
Set the IP traffic class/type-of-service for the channel.
- isAcceptResumed() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Determine whether accepts are resumed.
- isBlockingAllowed() - Static method in class org.xnio.Xnio
-
Determine whether blocking I/O is allowed from the current thread.
- isDaemon() - Method in class org.xnio.XnioWorker.Builder
- isDirect() - Method in class org.xnio.ByteBufferPool
-
Determine if this source returns direct buffers.
- isDirect(Buffer...) - Static method in class org.xnio.Buffers
-
Determine whether the given buffers list is comprised solely of direct buffers or solely of heap buffers.
- isDirect(Buffer[], int, int) - Static method in class org.xnio.Buffers
-
Determine whether the given buffers list is comprised solely of direct buffers or solely of heap buffers.
- isEmpty() - Method in class org.xnio.Sequence
-
Determine whether this sequence is empty.
- isEnqueued() - Method in class org.xnio.AutomaticReference
-
Deprecated.Determine whether this reference has been enqueued by the garbage collector.
- isOpen() - Method in class org.xnio.channels.AssembledChannel
- isOpen() - Method in class org.xnio.channels.AssembledMessageChannel
- isOpen() - Method in class org.xnio.channels.AssembledStreamChannel
- isOpen() - Method in class org.xnio.channels.BlockingByteChannel
- isOpen() - Method in class org.xnio.channels.BlockingReadableByteChannel
- isOpen() - Method in class org.xnio.channels.BlockingWritableByteChannel
- isOpen() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- isOpen() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- isOpen() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- isOpen() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Determine if this membership is active.
- isOpen() - Method in class org.xnio.channels.NullStreamSinkChannel
- isOpen() - Method in class org.xnio.channels.PushBackStreamChannel
- isOpen() - Method in class org.xnio.channels.SplitStreamSinkChannel
- isOpen() - Method in class org.xnio.channels.SplitStreamSourceChannel
- isOpen() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Determine whether this channel is open.
- isOpen() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Determine whether this channel is open.
- isOpen() - Method in class org.xnio.conduits.ConduitReadableByteChannel
- isOpen() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- isOpen() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- isOpen() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- isOpen() - Method in class org.xnio.conduits.ConduitWritableByteChannel
- isOpen() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- isOpen() - Method in class org.xnio.Connection
- isOpen() - Method in class org.xnio.ssl.JsseSslConnection
- isReadResumed() - Method in class org.xnio.channels.AssembledMessageChannel
- isReadResumed() - Method in class org.xnio.channels.AssembledStreamChannel
- isReadResumed() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- isReadResumed() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- isReadResumed() - Method in class org.xnio.channels.PushBackStreamChannel
- isReadResumed() - Method in class org.xnio.channels.SplitStreamSourceChannel
- isReadResumed() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Determine whether reads are resumed.
- isReadResumed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- isReadResumed() - Method in class org.xnio.conduits.AbstractSourceConduit
- isReadResumed() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- isReadResumed() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- isReadResumed() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- isReadResumed() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- isReadResumed() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- isReadResumed() - Method in interface org.xnio.conduits.SourceConduit
-
Determine whether read notifications are currently enabled.
- isReadResumed() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- isReadShutdown() - Method in class org.xnio.conduits.AbstractSourceConduit
- isReadShutdown() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- isReadShutdown() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- isReadShutdown() - Method in interface org.xnio.conduits.SourceConduit
-
Determine whether reads have been shut down on this conduit.
- isReadShutdown() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- isReadShutdown() - Method in class org.xnio.Connection
-
Determine whether reads have been shut down on this connection.
- isReadShutdown() - Method in class org.xnio.ssl.JsseSslConnection
- isReadShutdown() - Method in class org.xnio.ssl.JsseSslStreamConnection
- isReadShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Determine whether the channel is shut down for reads.
- isSecureBufferPool(Pool<?>) - Static method in class org.xnio.Buffers
-
Determine whether the given pool is a secure pool.
- isShutdown() - Method in class org.xnio.XnioWorker
-
Determine whether the worker has been shut down.
- isShutdownRequested() - Method in interface org.xnio.management.XnioWorkerMXBean
-
Determine whether shutdown has been requested for this worker.
- isTaskPoolExternal() - Method in class org.xnio.XnioWorker
-
Determine whether the worker task pool is managed externally.
- isTerminated() - Method in class org.xnio.XnioWorker
-
Determine whether the worker has terminated.
- isWriteComplete() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- isWriteResumed() - Method in class org.xnio.channels.AssembledMessageChannel
- isWriteResumed() - Method in class org.xnio.channels.AssembledStreamChannel
- isWriteResumed() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- isWriteResumed() - Method in class org.xnio.channels.NullStreamSinkChannel
- isWriteResumed() - Method in class org.xnio.channels.SplitStreamSinkChannel
- isWriteResumed() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Determine whether writes are resumed.
- isWriteResumed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- isWriteResumed() - Method in class org.xnio.conduits.AbstractSinkConduit
- isWriteResumed() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- isWriteResumed() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- isWriteResumed() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- isWriteResumed() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- isWriteResumed() - Method in class org.xnio.conduits.NullStreamSinkConduit
- isWriteResumed() - Method in interface org.xnio.conduits.SinkConduit
-
Determine whether write notifications are currently enabled.
- isWriteResumed() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- isWriteShutdown() - Method in class org.xnio.conduits.AbstractSinkConduit
- isWriteShutdown() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- isWriteShutdown() - Method in class org.xnio.conduits.NullStreamSinkConduit
- isWriteShutdown() - Method in interface org.xnio.conduits.SinkConduit
-
Determine whether writes have been fully shut down on this conduit.
- isWriteShutdown() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- isWriteShutdown() - Method in class org.xnio.Connection
-
Determine whether writes have been shut down on this connection.
- isWriteShutdown() - Method in class org.xnio.ssl.JsseSslConnection
- isWriteShutdown() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Determine whether writes have been shut down on this connection.
- isWriteShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Determine whether the channel is shut down for writes.
- iterator() - Method in class org.xnio.OptionMap
-
Iterate over the options in this map.
- iterator() - Method in class org.xnio.Sequence
-
Get an iterator over the elements of this sequence.
J
- java.nio.channels - package java.nio.channels
- join(InetAddress, NetworkInterface) - Method in interface org.xnio.channels.MulticastMessageChannel
-
Join a multicast group to begin receiving all datagrams sent to the group.
- join(InetAddress, NetworkInterface, InetAddress) - Method in interface org.xnio.channels.MulticastMessageChannel
-
Join a multicast group to begin receiving all datagrams sent to the group from a given source address.
- JsseSslConnection - Class in org.xnio.ssl
- JsseSslConnection(StreamConnection, SSLEngine) - Constructor for class org.xnio.ssl.JsseSslConnection
- JsseSslStreamConnection - Class in org.xnio.ssl
-
StreamConnection with SSL support.
- JsseSslStreamConnection(StreamConnection, SSLEngine, boolean) - Constructor for class org.xnio.ssl.JsseSslStreamConnection
- JsseSslUtils - Class in org.xnio.ssl
-
Utility methods for creating JSSE constructs and configuring them via XNIO option maps.
- JsseXnioSsl - Class in org.xnio.ssl
-
An XNIO SSL provider based on JSSE.
- JsseXnioSsl(Xnio, OptionMap) - Constructor for class org.xnio.ssl.JsseXnioSsl
-
Construct a new instance.
- JsseXnioSsl(Xnio, OptionMap, SSLContext) - Constructor for class org.xnio.ssl.JsseXnioSsl
-
Construct a new instance.
K
- KEEP_ALIVE - Static variable in class org.xnio.Options
-
Configure a channel to send TCP keep-alive messages in an implementation-dependent manner.
L
- LARGE_DIRECT - Static variable in class org.xnio.ByteBufferPool
-
The large direct buffer pool.
- LARGE_HEAP - Static variable in class org.xnio.ByteBufferPool
-
The large heap buffer pool.
- LARGE_SIZE - Static variable in class org.xnio.ByteBufferPool
-
The size of large buffers.
- lastIndexOf(char) - Method in class org.xnio.ByteString
-
Get the last index of the given character in this string.
- lastIndexOf(char, int) - Method in class org.xnio.ByteString
-
Get the last index of the given character in this string.
- lastIndexOf(String) - Method in class org.xnio.ByteString
- lastIndexOf(String, int) - Method in class org.xnio.ByteString
- lastIndexOf(ByteString) - Method in class org.xnio.ByteString
- lastIndexOf(ByteString, int) - Method in class org.xnio.ByteString
- lastIndexOfIgnoreCase(String) - Method in class org.xnio.ByteString
- lastIndexOfIgnoreCase(String, int) - Method in class org.xnio.ByteString
- lastIndexOfIgnoreCase(ByteString) - Method in class org.xnio.ByteString
- lastIndexOfIgnoreCase(ByteString, int) - Method in class org.xnio.ByteString
- length() - Method in class org.xnio.ByteString
-
Get the number of bytes in this byte string.
- limit(T, int) - Static method in class org.xnio.Buffers
-
Set the buffer limit.
- LimitedInputStream - Class in org.xnio.streams
-
An input stream which truncates the underlying stream to the given length.
- LimitedInputStream(InputStream, long) - Constructor for class org.xnio.streams.LimitedInputStream
-
Construct a new instance.
- LimitedOutputStream - Class in org.xnio.streams
-
An output stream which truncates the writable output to the given length.
- LimitedOutputStream(OutputStream, long) - Constructor for class org.xnio.streams.LimitedOutputStream
-
Construct a new instance.
- listenerException(Throwable) - Method in class org.xnio._private.Messages_$logger
- listenerException(Throwable) - Method in interface org.xnio._private.Messages
- listenerException$str() - Method in class org.xnio._private.Messages_$logger
- listenerMsg - Static variable in interface org.xnio._private.Messages
- LocalSocketAddress - Class in org.xnio
-
A socket address which is a local (UNIX domain) socket.
- LocalSocketAddress(String) - Constructor for class org.xnio.LocalSocketAddress
-
Construct a new instance.
- lock - Variable in class org.xnio.conduits.AbstractSynchronizedConduit
- lock() - Method in class java.nio.channels.FileChannel
- lock(long, long, boolean) - Method in class java.nio.channels.FileChannel
- longBitMask(int, int) - Static method in class org.xnio.Bits
-
Get a long bit mask consisting of 1 bits in the given range.
- longFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 64-bit signed big-endian long value from a byte array.
- longFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 64-bit signed little-endian long value from a byte array.
- LOW - Enum constant in enum org.xnio.sasl.SaslStrength
-
Specify low cipher strength.
M
- main(String[]) - Static method in class org.xnio.Version
-
Print out the current XNIO version on
System.out
. - malformedInput() - Method in class org.xnio._private.Messages_$logger
- malformedInput() - Method in interface org.xnio._private.Messages
- malformedInput$str() - Method in class org.xnio._private.Messages_$logger
- ManagementRegistration - Interface in org.xnio
- map(FileChannel.MapMode, long, long) - Method in class java.nio.channels.FileChannel
- MapMode() - Constructor for class java.nio.channels.FileChannel.MapMode
- mark(int) - Method in class org.xnio.streams.LimitedInputStream
- mark(T) - Static method in class org.xnio.Buffers
-
Set the buffer mark.
- markNotSet() - Method in class org.xnio._private.Messages_$logger
- markNotSet() - Method in interface org.xnio._private.Messages
- markNotSet$str() - Method in class org.xnio._private.Messages_$logger
- markSupported() - Method in class org.xnio.streams.LimitedInputStream
- MAX_INBOUND_MESSAGE_SIZE - Static variable in class org.xnio.Options
-
The maximum inbound message size.
- MAX_OUTBOUND_MESSAGE_SIZE - Static variable in class org.xnio.Options
-
The maximum outbound message size.
- MEDIUM - Enum constant in enum org.xnio.sasl.SaslStrength
-
Specify medium cipher strength.
- MEDIUM_DIRECT - Static variable in class org.xnio.ByteBufferPool
-
The medium direct buffer pool.
- MEDIUM_HEAP - Static variable in class org.xnio.ByteBufferPool
-
The medium heap buffer pool.
- MEDIUM_SIZE - Static variable in class org.xnio.ByteBufferPool
-
The size of medium buffers.
- mediumFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 24-bit signed big-endian int value from a byte array.
- mediumFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 24-bit signed little-endian int value from a byte array.
- MessageChannel - Interface in org.xnio.channels
-
A channel that sends and receives whole messages.
- MessageConnection - Class in org.xnio
-
A message-oriented connection between peers.
- MessageConnection(XnioIoThread) - Constructor for class org.xnio.MessageConnection
-
Construct a new instance.
- Messages - Interface in org.xnio._private
- Messages_$logger - Class in org.xnio._private
-
Warning this class consists of generated code.
- Messages_$logger(Logger) - Constructor for class org.xnio._private.Messages_$logger
- MessageSinkConduit - Interface in org.xnio.conduits
-
A message sink conduit.
- MessageSourceConduit - Interface in org.xnio.conduits
-
A message source conduit.
- MessageStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit which wraps each write into a single message.
- MessageStreamSinkConduit(MessageSinkConduit) - Constructor for class org.xnio.conduits.MessageStreamSinkConduit
-
Construct a new instance.
- MessageStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which reads stream data from messages.
- MessageStreamSourceConduit(MessageSourceConduit) - Constructor for class org.xnio.conduits.MessageStreamSourceConduit
-
Construct a new instance.
- minRange(String, int) - Method in class org.xnio._private.Messages_$logger
- minRange(String, int) - Method in interface org.xnio._private.Messages
- minRange$str() - Method in class org.xnio._private.Messages_$logger
- mismatchAddressType(Class<? extends InetAddress>, Class<? extends InetAddress>) - Method in class org.xnio._private.Messages_$logger
- mismatchAddressType(Class<? extends InetAddress>, Class<? extends InetAddress>) - Method in interface org.xnio._private.Messages
- mismatchAddressType$str() - Method in class org.xnio._private.Messages_$logger
- mismatchSockType(Class<? extends SocketAddress>, Class<? extends SocketAddress>) - Method in class org.xnio._private.Messages_$logger
- mismatchSockType(Class<? extends SocketAddress>, Class<? extends SocketAddress>) - Method in interface org.xnio._private.Messages
- mismatchSockType$str() - Method in class org.xnio._private.Messages_$logger
- missingSslProvider() - Method in class org.xnio._private.Messages_$logger
- missingSslProvider() - Method in interface org.xnio._private.Messages
- missingSslProvider$str() - Method in class org.xnio._private.Messages_$logger
- mixedDirectAndHeap() - Method in class org.xnio._private.Messages_$logger
- mixedDirectAndHeap() - Method in interface org.xnio._private.Messages
- mixedDirectAndHeap$str() - Method in class org.xnio._private.Messages_$logger
- MODIFIED - Enum constant in enum org.xnio.FileChangeEvent.Type
-
A file was modified in a directory.
- msg - Static variable in interface org.xnio._private.Messages
- MULTICAST - Static variable in class org.xnio.Options
-
Enable multicast support for a socket.
- MULTICAST_TTL - Static variable in class org.xnio.Options
-
Set the multicast time-to-live field for datagram sockets.
- MulticastMessageChannel - Interface in org.xnio.channels
-
A multicast-capable point-to-multipoint channel.
- MulticastMessageChannel.Key - Interface in org.xnio.channels
-
A registration key for a multicast group.
- MultipointMessageChannel - Interface in org.xnio.channels
-
A point-to-multipoint message channel.
N
- NEW_IMPL - Static variable in class org.xnio.ssl.JsseXnioSsl
- next - Variable in class org.xnio.conduits.AbstractConduit
-
The delegate conduit.
- NIO2 - Static variable in class org.xnio.Xnio
-
A flag indicating the presence of NIO.2 (JDK 7).
- noField(String, Class<?>) - Method in class org.xnio._private.Messages_$logger
- noField(String, Class<?>) - Method in interface org.xnio._private.Messages
- noField$str() - Method in class org.xnio._private.Messages_$logger
- noOptionParser() - Method in class org.xnio._private.Messages_$logger
- noOptionParser() - Method in interface org.xnio._private.Messages
- noOptionParser$str() - Method in class org.xnio._private.Messages_$logger
- noProviderFound() - Method in class org.xnio._private.Messages_$logger
- noProviderFound() - Method in interface org.xnio._private.Messages
- noProviderFound$str() - Method in class org.xnio._private.Messages_$logger
- NOT_REQUESTED - Enum constant in enum org.xnio.SslClientAuthMode
-
SSL client authentication is not requested.
- notFromThisProvider() - Method in class org.xnio._private.Messages_$logger
- notFromThisProvider() - Method in interface org.xnio._private.Messages
- notFromThisProvider$str() - Method in class org.xnio._private.Messages_$logger
- notifierFailed(Throwable, IoFuture.Notifier<?, ?>, Object) - Method in class org.xnio._private.Messages_$logger
- notifierFailed(Throwable, IoFuture.Notifier<?, ?>, Object) - Method in interface org.xnio._private.Messages
- notifierFailed$str() - Method in class org.xnio._private.Messages_$logger
- notify(IoFuture<? extends T>, A) - Method in class org.xnio.IoFuture.HandlingNotifier
-
Receive notification of the completion of an outstanding operation.
- notify(IoFuture<? extends T>, A) - Method in interface org.xnio.IoFuture.Notifier
-
Receive notification of the completion of an outstanding operation.
- notifyReadClosed() - Method in class org.xnio.Connection
-
Indicate to conduit handlers that reads have been closed.
- notifyReadClosed() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Indicate to conduit handlers that reads have been closed.
- notifyReadClosed() - Method in class org.xnio.StreamConnection
- notifyWriteClosed() - Method in class org.xnio.Connection
-
Indicate to conduit handlers that writes have been closed.
- notifyWriteClosed() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Indicate to conduit handlers that writes have been closed.
- notifyWriteClosed() - Method in class org.xnio.StreamConnection
- nullArrayIndex(String, int) - Method in class org.xnio._private.Messages_$logger
- nullArrayIndex(String, int) - Method in interface org.xnio._private.Messages
- nullArrayIndex$str() - Method in class org.xnio._private.Messages_$logger
- nullCancellable() - Static method in class org.xnio.IoUtils
-
Get the null cancellable.
- nullChannelListener() - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which does nothing.
- nullCloseable() - Static method in class org.xnio.IoUtils
-
Get the null closeable.
- nullExecutor() - Static method in class org.xnio.IoUtils
-
Get the null executor.
- nullParameter(String) - Method in class org.xnio._private.Messages_$logger
- nullParameter(String) - Method in interface org.xnio._private.Messages
- nullParameter$str() - Method in class org.xnio._private.Messages_$logger
- nullSetter() - Static method in class org.xnio.ChannelListeners
-
Get a channel listener setter which does nothing.
- NullStreamSinkChannel - Class in org.xnio.channels
-
A bit-bucket stream sink channel.
- NullStreamSinkChannel(XnioIoThread) - Constructor for class org.xnio.channels.NullStreamSinkChannel
-
Construct a new instance.
- NullStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit which discards all data written to it.
- NullStreamSinkConduit(XnioIoThread) - Constructor for class org.xnio.conduits.NullStreamSinkConduit
-
Construct a new instance.
O
- of(byte...) - Static method in class org.xnio.ByteString
-
Create a byte string of the given literal bytes.
- of(String, Object) - Static method in class org.xnio.Property
-
Create a new property for the specified key and value.
- of(String, String) - Static method in class org.xnio.Property
-
Create a new property for the specified key and value.
- of(Collection<T>) - Static method in class org.xnio.Sequence
-
Return a sequence of the given members.
- of(T...) - Static method in class org.xnio.Sequence
-
Return a sequence of the given members.
- oneChannelMustBeConnection() - Method in class org.xnio._private.Messages_$logger
- oneChannelMustBeConnection() - Method in interface org.xnio._private.Messages
- oneChannelMustBeConnection$str() - Method in class org.xnio._private.Messages_$logger
- oneChannelMustBeSSL() - Method in class org.xnio._private.Messages_$logger
- oneChannelMustBeSSL() - Method in interface org.xnio._private.Messages
- oneChannelMustBeSSL$str() - Method in class org.xnio._private.Messages_$logger
- opCancelled() - Method in class org.xnio._private.Messages_$logger
- opCancelled() - Method in interface org.xnio._private.Messages
- opCancelled$str() - Method in class org.xnio._private.Messages_$logger
- open(Path, OpenOption...) - Static method in class java.nio.channels.FileChannel
- open(ChannelListener<? super T>) - Method in interface org.xnio.ChannelSource
-
Open a channel.
- openFile(File, FileAccess) - Method in class org.xnio.Xnio
-
Open a file on the filesystem.
- openFile(File, OptionMap) - Method in class org.xnio.Xnio
-
Open a file on the filesystem.
- openFile(String, FileAccess) - Method in class org.xnio.Xnio
-
Open a file on the filesystem.
- openFile(String, OptionMap) - Method in class org.xnio.Xnio
-
Open a file on the filesystem.
- openListenerAdapter(ChannelListener<? super C>) - Static method in class org.xnio.ChannelListeners
-
Create an open listener adapter which automatically accepts connections and invokes an open listener.
- openLocalMessageConnection(LocalSocketAddress, LocalSocketAddress, ChannelListener<? super MessageConnection>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to connect to a local (UNIX domain) server.
- openLocalStreamConnection(LocalSocketAddress, LocalSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to connect to a local (UNIX domain) server.
- openMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Connect to a remote message server.
- openMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, OptionMap) - Method in class org.xnio.XnioIoThread
- openMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, OptionMap) - Method in class org.xnio.XnioWorker
- openModeRequires7() - Method in class org.xnio._private.Messages_$logger
- openModeRequires7() - Method in interface org.xnio._private.Messages
- openModeRequires7$str() - Method in class org.xnio._private.Messages_$logger
- openSslConnection(XnioIoThread, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
- openSslConnection(XnioIoThread, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioIoThread, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioIoThread, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioIoThread, InetSocketAddress, ChannelListener<? super SslConnection>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
- openSslConnection(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super SslConnection>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioWorker, InetSocketAddress, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openSslConnection(XnioWorker, InetSocketAddress, ChannelListener<? super SslConnection>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create an SSL connection to a remote host.
- openStreamConnection(SocketAddress, SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Connect to a remote stream server.
- openStreamConnection(SocketAddress, SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
- openStreamConnection(SocketAddress, SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Connect to a remote stream server.
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Connect to a remote stream server.
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, OptionMap) - Method in class org.xnio.XnioIoThread
- openStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, OptionMap) - Method in class org.xnio.XnioWorker
- openTcpStreamConnection(InetSocketAddress, InetSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to connect to a TCP server.
- opTimedOut() - Method in class org.xnio._private.Messages_$logger
- opTimedOut() - Method in interface org.xnio._private.Messages
- opTimedOut$str() - Method in class org.xnio._private.Messages_$logger
- Option<T> - Class in org.xnio
-
A strongly-typed option to configure an aspect of a service or connection.
- Option.SetBuilder - Class in org.xnio
-
A builder for an immutable option set.
- optionClassNotFound(String, ClassLoader) - Method in class org.xnio._private.Messages_$logger
- optionClassNotFound(String, ClassLoader) - Method in interface org.xnio._private.Messages
- optionClassNotFound$str() - Method in class org.xnio._private.Messages_$logger
- OptionMap - Class in org.xnio
-
An immutable map of options to option values.
- OptionMap.Builder - Class in org.xnio
-
A builder for immutable option maps.
- optionParseMsg - Static variable in interface org.xnio._private.Messages
- Options - Class in org.xnio
-
Common channel options.
- org.xnio - package org.xnio
-
The main API package for XNIO.
- org.xnio._private - package org.xnio._private
- org.xnio.channels - package org.xnio.channels
-
The core XNIO channel API.
- org.xnio.conduits - package org.xnio.conduits
-
The XNIO conduit SPI.
- org.xnio.http - package org.xnio.http
- org.xnio.management - package org.xnio.management
- org.xnio.sasl - package org.xnio.sasl
-
Utility classes for using SASL mechanisms atop NIO or XNIO APIs.
- org.xnio.ssl - package org.xnio.ssl
-
Utility classes for using and implementing SSL within XNIO providers.
- org.xnio.streams - package org.xnio.streams
-
Utility classes for creating streams which use XNIO channels.
P
- parameterOutOfRange(String) - Method in class org.xnio._private.Messages_$logger
- parameterOutOfRange(String) - Method in interface org.xnio._private.Messages
- parameterOutOfRange$str() - Method in class org.xnio._private.Messages_$logger
- parse(Option<T>, String) - Method in class org.xnio.OptionMap.Builder
-
Set a key-value pair, parsing the value from the given string.
- parse(Option<T>, String, ClassLoader) - Method in class org.xnio.OptionMap.Builder
-
Set a key-value pair, parsing the value from the given string.
- parseAll(Properties, String) - Method in class org.xnio.OptionMap.Builder
-
Add all options from a properties file.
- parseAll(Properties, String, ClassLoader) - Method in class org.xnio.OptionMap.Builder
-
Add all options from a properties file.
- parseValue(String, ClassLoader) - Method in class org.xnio.Option
-
Parse a string value for this option.
- performUpgrade(XnioWorker, InetSocketAddress, URI, Map<String, String>, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap, HandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Connects to the target server using HTTP upgrade.
- performUpgrade(XnioWorker, InetSocketAddress, URI, Map<String, List<String>>, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap, ExtendedHandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Connects to the target server using HTTP upgrade.
- performUpgrade(XnioWorker, XnioSsl, InetSocketAddress, URI, Map<String, String>, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap, HandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Perform a HTTP upgrade that results in a SSL secured connection.
- performUpgrade(XnioWorker, XnioSsl, InetSocketAddress, URI, Map<String, List<String>>, ChannelListener<? super SslConnection>, ChannelListener<? super BoundChannel>, OptionMap, ExtendedHandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Perform a HTTP upgrade that results in a SSL secured connection.
- performUpgrade(T, URI, Map<String, String>, ChannelListener<? super StreamConnection>, HandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Performs a HTTP upgrade on an existing connection.
- performUpgrade(T, URI, Map<String, List<String>>, ChannelListener<? super StreamConnection>, ExtendedHandshakeChecker) - Static method in class org.xnio.http.HttpUpgrade
-
Performs a HTTP upgrade on an existing connection.
- Pipe - Class in org.xnio.streams
-
An in-VM pipe between an input stream and an output stream, which does not suffer from the bugs in
PipedInputStream
. - Pipe(int) - Constructor for class org.xnio.streams.Pipe
-
Construct a new instance.
- Pool<T> - Interface in org.xnio
-
Deprecated.See
ByteBufferPool
. - Pooled<T> - Interface in org.xnio
-
Deprecated.See
ByteBufferPool
. - pooledWrapper(B) - Static method in class org.xnio.Buffers
-
Create a pooled wrapper around a buffer.
- populateFromOptions(OptionMap) - Method in class org.xnio.XnioWorker.Builder
- position() - Method in class java.nio.channels.FileChannel
- position(long) - Method in class java.nio.channels.FileChannel
- position(T, int) - Static method in class org.xnio.Buffers
-
Set the buffer position.
- PRIVATE - Static variable in class java.nio.channels.FileChannel.MapMode
- Property - Class in org.xnio
-
An immutable property represented by a key and value.
- propReadForbidden() - Method in class org.xnio._private.Messages_$logger
- propReadForbidden() - Method in interface org.xnio._private.Messages
- propReadForbidden$str() - Method in class org.xnio._private.Messages_$logger
- ProtectedWrappedChannel<C> - Interface in org.xnio.channels
-
A protected, wrapped channel.
- push(ByteBuffer) - Method in class org.xnio.streams.BufferPipeInputStream
-
Push a buffer into the queue.
- push(Pooled<ByteBuffer>) - Method in class org.xnio.streams.BufferPipeInputStream
-
Push a buffer into the queue.
- pushBack(Pooled<ByteBuffer>) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
Push a buffer back to the head of the stream.
- PushBackStreamChannel - Class in org.xnio.channels
-
A stream source channel which can have data pushed back into it.
- PushBackStreamChannel(StreamSourceChannel) - Constructor for class org.xnio.channels.PushBackStreamChannel
-
Construct a new instance.
- PushBackStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which allows buffers to be "pushed back" to the head of the stream.
- PushBackStreamSourceConduit(StreamSourceConduit) - Constructor for class org.xnio.conduits.PushBackStreamSourceConduit
-
Construct a new instance.
- pushEof() - Method in class org.xnio.streams.BufferPipeInputStream
-
Push the EOF condition into the queue.
- pushException(IOException) - Method in class org.xnio.streams.BufferPipeInputStream
-
Push an exception condition into the queue.
- putModifiedUtf8(ByteBuffer, String) - Static method in class org.xnio.Buffers
-
Put the string into the byte buffer, encoding it using "modified UTF-8" encoding.
R
- randomWrongThread() - Method in class org.xnio._private.Messages_$logger
- randomWrongThread() - Method in interface org.xnio._private.Messages
- randomWrongThread$str() - Method in class org.xnio._private.Messages_$logger
- read() - Method in class org.xnio.streams.BufferedChannelInputStream
-
Read a byte, blocking if necessary.
- read() - Method in class org.xnio.streams.BufferPipeInputStream
- read() - Method in class org.xnio.streams.ChannelInputStream
- read() - Method in class org.xnio.streams.LimitedInputStream
- read() - Method in class org.xnio.streams.ReaderInputStream
- read(byte[]) - Method in class org.xnio.streams.ChannelInputStream
- read(byte[], int, int) - Method in class org.xnio.streams.BufferedChannelInputStream
-
Read bytes into an array.
- read(byte[], int, int) - Method in class org.xnio.streams.BufferPipeInputStream
- read(byte[], int, int) - Method in class org.xnio.streams.ChannelInputStream
- read(byte[], int, int) - Method in class org.xnio.streams.LimitedInputStream
- read(byte[], int, int) - Method in class org.xnio.streams.ReaderInputStream
- read(ByteBuffer) - Method in class java.nio.channels.FileChannel
- read(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
- read(ByteBuffer) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking read operation.
- read(ByteBuffer) - Method in class org.xnio.channels.BlockingReadableByteChannel
-
Perform a blocking read operation.
- read(ByteBuffer) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- read(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- read(ByteBuffer) - Method in class org.xnio.channels.PushBackStreamChannel
- read(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSourceChannel
- read(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.ConduitReadableByteChannel
- read(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- read(ByteBuffer) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- read(ByteBuffer) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- read(ByteBuffer) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Read a sequence of bytes from this conduit to the given buffer.
- read(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedStreamSourceConduit
- read(ByteBuffer[]) - Method in class java.nio.channels.FileChannel
- read(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
- read(ByteBuffer[]) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, scattering read operation.
- read(ByteBuffer[]) - Method in class org.xnio.channels.BlockingReadableByteChannel
-
Perform a blocking, scattering read operation.
- read(ByteBuffer[]) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- read(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- read(ByteBuffer[]) - Method in class org.xnio.channels.PushBackStreamChannel
- read(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSourceChannel
- read(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- read(ByteBuffer[]) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class java.nio.channels.FileChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, scattering read operation.
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingReadableByteChannel
-
Perform a blocking, scattering read operation.
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.PushBackStreamChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSourceChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- read(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Read a sequence of bytes from this conduit to the given buffers.
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedStreamSourceConduit
- read(ByteBuffer, long) - Method in class java.nio.channels.FileChannel
- READ_ONLY - Enum constant in enum org.xnio.FileAccess
- READ_ONLY - Static variable in class java.nio.channels.FileChannel.MapMode
- READ_TIMEOUT - Static variable in class org.xnio.Options
-
Configure a read timeout for a socket, in milliseconds.
- READ_WRITE - Enum constant in enum org.xnio.FileAccess
- READ_WRITE - Static variable in class java.nio.channels.FileChannel.MapMode
- ReadableMessageChannel - Interface in org.xnio.channels
-
A channel that can receive messages.
- ReadableMultipointMessageChannel - Interface in org.xnio.channels
-
The readable side of a multipoint message channel.
- readAppendNotSupported() - Method in class org.xnio._private.Messages_$logger
- readAppendNotSupported() - Method in interface org.xnio._private.Messages
- readAppendNotSupported$str() - Method in class org.xnio._private.Messages_$logger
- readAscii(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read the remainder of a buffer as ASCII text, appending the results to the given string builder.
- readAscii(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read the remainder of a buffer as ASCII text, appending the results to the given string builder.
- readAscii(ByteBuffer, StringBuilder, int, char) - Static method in class org.xnio.Buffers
-
Read the remainder of a buffer as ASCII text, up to a certain limit, appending the results to the given string builder.
- readAsciiLine(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a single line of ASCII text from a byte buffer, appending the results to the given string builder.
- readAsciiLine(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read a single line of ASCII text from a byte buffer, appending the results to the given string builder.
- readAsciiLine(ByteBuffer, StringBuilder, char, char) - Static method in class org.xnio.Buffers
-
Read a single line of ASCII text from a byte buffer, appending the results to the given string builder, using the given delimiter character instead of
EOL
. - readAsciiZ(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read an ASCIIZ (
NUL
-terminated) string from a byte buffer, appending the results to the given string builder. - readAsciiZ(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read an ASCIIZ (
NUL
-terminated) string from a byte buffer, appending the results to the given string builder. - readBlocking(C, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking read on a readable byte channel.
- readBlocking(C, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking read on a scattering byte channel.
- readBlocking(C, ByteBuffer[], int, int, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking read on a scattering byte channel with a timeout.
- readBlocking(C, ByteBuffer, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking read on a readable byte channel with a timeout.
- readClosed() - Method in class org.xnio.Connection
-
Indicate that reads have been closed on this connection.
- readClosed() - Method in class org.xnio.ssl.JsseSslStreamConnection
- ReaderInputStream - Class in org.xnio.streams
-
An input stream which encodes characters into bytes.
- ReaderInputStream(Reader) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, String) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, Charset) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, CharsetEncoder) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, CharsetEncoder, int) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- readLatin1(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read the remainder of a buffer as Latin-1 text, appending the results to the given string builder.
- readLatin1Line(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a single line of Latin-1 text from a byte buffer, appending the results to the given string builder.
- readLatin1Line(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read a single line of Latin-1 text from a byte buffer, appending the results to the given string builder.
- readLatin1Z(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a
NUL
-terminated Latin-1 string from a byte buffer, appending the results to the given string builder. - readLine(ByteBuffer, StringBuilder, CharsetDecoder) - Static method in class org.xnio.Buffers
-
Read a single line of text from a byte buffer, appending the results to the given string builder.
- readLine(ByteBuffer, StringBuilder, CharsetDecoder, char) - Static method in class org.xnio.Buffers
-
Read a single line of text from a byte buffer, appending the results to the given string builder.
- ReadListenerSettable<C> - Interface in org.xnio.channels
-
An object which supports directly setting the read listener may implement this interface.
- ReadListenerSettable.Setter<C> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- readModifiedUtf8Line(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a single line of
modified UTF-8
text from a byte buffer, appending the results to the given string builder. - readModifiedUtf8Line(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read a single line of
modified UTF-8
text from a byte buffer, appending the results to the given string builder. - readModifiedUtf8Line(ByteBuffer, StringBuilder, char, char) - Static method in class org.xnio.Buffers
-
Read a single line of
modified UTF-8
text from a byte buffer, appending the results to the given string builder. - readModifiedUtf8Z(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a
NUL
-terminatedmodified UTF-8
string from a byte buffer, appending the results to the given string builder. - readModifiedUtf8Z(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read a
NUL
-terminatedmodified UTF-8
string from a byte buffer, appending the results to the given string builder. - readOnlyBuffer() - Method in class org.xnio._private.Messages_$logger
- readOnlyBuffer() - Method in interface org.xnio._private.Messages
- readOnlyBuffer$str() - Method in class org.xnio._private.Messages_$logger
- ReadPropertyAction - Class in org.xnio
-
A simple property-read privileged action.
- ReadPropertyAction(String, String) - Constructor for class org.xnio.ReadPropertyAction
-
Construct a new instance.
- readReady() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
- readReady() - Method in interface org.xnio.conduits.ReadReadyHandler
-
Signify that reads are ready.
- ReadReadyHandler - Interface in org.xnio.conduits
-
A conduit read-ready handler.
- ReadReadyHandler.ChannelListenerHandler<C> - Class in org.xnio.conduits
-
A read ready handler which calls channel listener(s).
- ReadReadyHandler.ReadyTask - Class in org.xnio.conduits
-
A runnable task which invokes the
ReadReadyHandler.readReady()
method of the given handler. - readRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate if the channel is not readable until the write handler is called.
- readResolve() - Method in class org.xnio.Option
-
Resolve this instance for serialization.
- readSuspendingChannelListener(ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
A read-suspending channel listener.
- readTimeout() - Method in class org.xnio._private.Messages_$logger
- readTimeout() - Method in interface org.xnio._private.Messages
- readTimeout$str() - Method in class org.xnio._private.Messages_$logger
- ReadTimeoutException - Exception Class in org.xnio.channels
-
Thrown when a blocking read operation times out.
- ReadTimeoutException() - Constructor for exception class org.xnio.channels.ReadTimeoutException
-
Constructs a
ReadTimeoutException
with no detail message. - ReadTimeoutException(String) - Constructor for exception class org.xnio.channels.ReadTimeoutException
-
Constructs a
ReadTimeoutException
with the specified detail message. - ReadTimeoutException(String, Throwable) - Constructor for exception class org.xnio.channels.ReadTimeoutException
-
Constructs a
ReadTimeoutException
with the specified detail message and cause. - ReadTimeoutException(Throwable) - Constructor for exception class org.xnio.channels.ReadTimeoutException
-
Constructs a
ReadTimeoutException
with the specified cause. - ReadyTask(ReadReadyHandler) - Constructor for class org.xnio.conduits.ReadReadyHandler.ReadyTask
-
Construct a new instance.
- ReadyTask(TerminateHandler) - Constructor for class org.xnio.conduits.TerminateHandler.ReadyTask
-
Construct a new instance.
- ReadyTask(WriteReadyHandler) - Constructor for class org.xnio.conduits.WriteReadyHandler.ReadyTask
-
Construct a new instance.
- receive(ByteBuffer) - Method in class org.xnio.channels.AssembledMessageChannel
- receive(ByteBuffer) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Receive a message.
- receive(ByteBuffer) - Method in interface org.xnio.channels.ReadableMessageChannel
-
Receive a message.
- receive(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSourceConduit
- receive(ByteBuffer) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- receive(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSourceConduit
- receive(ByteBuffer) - Method in interface org.xnio.conduits.MessageSourceConduit
-
Receive a message.
- receive(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedMessageSourceConduit
- receive(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
- receive(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Receive a message.
- receive(ByteBuffer[]) - Method in interface org.xnio.channels.ReadableMessageChannel
-
Receive a message.
- receive(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- receive(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
- receive(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Receive a message.
- receive(ByteBuffer[], int, int) - Method in interface org.xnio.channels.ReadableMessageChannel
-
Receive a message.
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSourceConduit
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSourceConduit
- receive(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSourceConduit
-
Receive a message.
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedMessageSourceConduit
- RECEIVE_BUFFER - Static variable in class org.xnio.Options
-
The receive buffer size.
- receiveBlocking(C, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking receive on a readable message channel.
- receiveBlocking(C, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking receive on a readable message channel.
- receiveBlocking(C, ByteBuffer[], int, int, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking receive on a readable message channel with a timeout.
- receiveBlocking(C, ByteBuffer, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking receive on a readable message channel with a timeout.
- receiveFrom(SocketAddressBuffer, ByteBuffer) - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Receive a message via this channel.
- receiveFrom(SocketAddressBuffer, ByteBuffer[]) - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Receive a message.
- receiveFrom(SocketAddressBuffer, ByteBuffer[], int, int) - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Receive a message.
- recvInvalidMsgLength(int) - Method in class org.xnio._private.Messages_$logger
- recvInvalidMsgLength(int) - Method in interface org.xnio._private.Messages
- recvInvalidMsgLength$str() - Method in class org.xnio._private.Messages_$logger
- redirect() - Method in class org.xnio._private.Messages_$logger
- redirect() - Method in interface org.xnio._private.Messages
- redirect$str() - Method in class org.xnio._private.Messages_$logger
- RedirectException - Exception Class in org.xnio.http
-
An extension of
IOException
used to convey that a connection has failed as a redirect has been encountered. - RedirectException(int, String) - Constructor for exception class org.xnio.http.RedirectException
-
Constructs a new
RedirectException
instance. - RedirectException(String, int, String) - Constructor for exception class org.xnio.http.RedirectException
-
Constructs a new
RedirectException
instance with an initial message. - RedirectException(String, Throwable, int, String) - Constructor for exception class org.xnio.http.RedirectException
-
Constructs a new
RedirectException
instance with an initial message and cause. - RedirectException(Throwable, int, String) - Constructor for exception class org.xnio.http.RedirectException
-
Constructs a new
RedirectException
instance with an initial cause. - regionMatches(boolean, int, byte[], int, int) - Method in class org.xnio.ByteString
- regionMatches(boolean, int, String, int, int) - Method in class org.xnio.ByteString
- regionMatches(boolean, int, ByteString, int, int) - Method in class org.xnio.ByteString
- register(XnioProviderMXBean) - Static method in class org.xnio.Xnio
-
Register an MBean.
- register(XnioServerMXBean) - Static method in class org.xnio.Xnio
-
Register an MBean.
- register(XnioWorkerMXBean) - Static method in class org.xnio.Xnio
-
Register an MBean.
- registerServerMXBean(XnioServerMXBean) - Method in class org.xnio.XnioWorker
- remaining(Buffer[]) - Static method in class org.xnio.Buffers
-
Get the total remaining size of all the given buffers.
- remaining(Buffer[], int, int) - Static method in class org.xnio.Buffers
-
Get the total remaining size of all the given buffers.
- remove() - Method in interface org.xnio.XnioExecutor.Key
-
Remove a previously-submitted task.
- REMOVED - Enum constant in enum org.xnio.FileChangeEvent.Type
-
A file was removed from a directory.
- removeReadRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that one external read task was completed.
- removeWriteRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that one external write task was completed.
- REQUESTED - Enum constant in enum org.xnio.SslClientAuthMode
-
SSL client authentication is requested but not required.
- requireCurrentThread() - Static method in class org.xnio.XnioIoThread
-
Get the current XNIO thread.
- REQUIRED - Enum constant in enum org.xnio.SslClientAuthMode
-
SSL client authentication is required.
- reset() - Method in class org.xnio.streams.LimitedInputStream
- reset(T) - Static method in class org.xnio.Buffers
-
Reset the buffer.
- resourceCloseFailed(Throwable, Object) - Method in class org.xnio._private.Messages_$logger
- resourceCloseFailed(Throwable, Object) - Method in interface org.xnio._private.Messages
- resourceCloseFailed$str() - Method in class org.xnio._private.Messages_$logger
- resourceReadShutdownFailed(Throwable, Object) - Method in class org.xnio._private.Messages_$logger
- resourceReadShutdownFailed(Throwable, Object) - Method in interface org.xnio._private.Messages
- resourceReadShutdownFailed$str() - Method in class org.xnio._private.Messages_$logger
- Result<T> - Interface in org.xnio
-
A handler for the result of an operation.
- resultNotifier() - Static method in class org.xnio.IoUtils
-
Get the result notifier.
- resumeAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Resume reads on this channel.
- resumeReads() - Method in class org.xnio.channels.AssembledMessageChannel
- resumeReads() - Method in class org.xnio.channels.AssembledStreamChannel
- resumeReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- resumeReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- resumeReads() - Method in class org.xnio.channels.PushBackStreamChannel
- resumeReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
- resumeReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Resume reads on this channel.
- resumeReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Resume reads on this channel.
- resumeReads() - Method in class org.xnio.conduits.AbstractSourceConduit
- resumeReads() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- resumeReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- resumeReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- resumeReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- resumeReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- resumeReads() - Method in class org.xnio.conduits.FramingMessageSourceConduit
- resumeReads() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- resumeReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that the conduit's
ReadReadyHandler
should be invoked as soon as data can be read without blocking. - resumeReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- resumeReadsAsync(SuspendableReadChannel) - Static method in class org.xnio.channels.Channels
-
Resume reads asynchronously.
- resumeWrites() - Method in class org.xnio.channels.AssembledMessageChannel
- resumeWrites() - Method in class org.xnio.channels.AssembledStreamChannel
- resumeWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- resumeWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
- resumeWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
- resumeWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Resume writes on this channel.
- resumeWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Resume writes on this channel.
- resumeWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
- resumeWrites() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- resumeWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- resumeWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- resumeWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- resumeWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
- resumeWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Indicate that the conduit's
WriteReadyHandler
should be invoked as soon as data can be written without blocking. - resumeWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- resumeWritesAsync(SuspendableWriteChannel) - Static method in class org.xnio.channels.Channels
-
Resume writes asynchronously.
- REUSE_ADDRESSES - Static variable in class org.xnio.Options
-
Configure an IP socket to reuse addresses.
- rewind(T) - Static method in class org.xnio.Buffers
-
Rewind the buffer.
- run() - Method in class org.xnio.Closer
- run() - Method in class org.xnio.conduits.ReadReadyHandler.ReadyTask
- run() - Method in class org.xnio.conduits.TerminateHandler.ReadyTask
- run() - Method in class org.xnio.conduits.WriteReadyHandler.ReadyTask
- run() - Method in class org.xnio.ReadPropertyAction
-
Run the action.
- runnableNotifier(Runnable) - Static method in class org.xnio.IoUtils
-
Get a notifier that runs the supplied action.
- runNotifier(Runnable) - Method in class org.xnio.AbstractIoFuture
-
Run a notifier.
- runWithCache(int, Runnable) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
- runWithCacheEx(int, ExceptionRunnable<E>) - Method in class org.xnio.ByteBufferPool
-
Perform the given operation with the addition of a buffer cache of the given size.
S
- safeClose(Closeable) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(Closeable...) - Static method in class org.xnio.IoUtils
-
Close a series of resources, logging errors if they occur.
- safeClose(AutoCloseable) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(DatagramSocket) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(ServerSocket) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(Socket) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(Selector) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(Handler) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(ZipFile) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(IoFuture<? extends Closeable>) - Static method in class org.xnio.IoUtils
-
Close a future resource, logging an error if an error occurs.
- safeShutdownReads(SuspendableReadChannel) - Static method in class org.xnio.IoUtils
-
Safely shutdown reads on the given channel.
- SASL_DISALLOWED_MECHANISMS - Static variable in class org.xnio.Options
-
A list of disallowed SASL mechanisms.
- SASL_MECHANISMS - Static variable in class org.xnio.Options
-
A list of SASL mechanisms, in decreasing order of preference.
- SASL_POLICY_FORWARD_SECRECY - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which implement forward secrecy between sessions are required.
- SASL_POLICY_NOACTIVE - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which are susceptible to active (non-dictionary) attacks are permitted.
- SASL_POLICY_NOANONYMOUS - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which accept anonymous logins are permitted.
- SASL_POLICY_NODICTIONARY - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which are susceptible to passive dictionary attacks are permitted.
- SASL_POLICY_NOPLAINTEXT - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which are susceptible to simple plain passive attacks are permitted.
- SASL_POLICY_PASS_CREDENTIALS - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms which pass client credentials are required.
- SASL_PROPERTIES - Static variable in class org.xnio.Options
-
A list of provider specific SASL properties.
- SASL_QOP - Static variable in class org.xnio.Options
-
Specify the SASL quality-of-protection to use.
- SASL_REUSE - Static variable in class org.xnio.Options
-
Specify whether SASL mechanisms should attempt to reuse authenticated session information.
- SASL_SERVER_AUTH - Static variable in class org.xnio.Options
-
Specify whether the SASL server must authenticate to the client.
- SASL_STRENGTH - Static variable in class org.xnio.Options
-
Specify the SASL cipher strength to use.
- SaslQop - Enum in org.xnio.sasl
-
The SASL quality-of-protection value.
- SaslStrength - Enum in org.xnio.sasl
-
The SASL cipher strength value.
- SaslUnwrappingConduit - Class in org.xnio.sasl
- SaslUnwrappingConduit(MessageSinkConduit, SaslWrapper) - Constructor for class org.xnio.sasl.SaslUnwrappingConduit
- SaslUtils - Class in org.xnio.sasl
-
Utility methods for handling SASL authentication using NIO-style programming methods.
- SaslWrapper - Class in org.xnio.sasl
-
A wrapper delegation class for SASL that presents the same wrap/unwrap API regardless of whether it is dealing with a SASL client or server.
- SaslWrapper() - Constructor for class org.xnio.sasl.SaslWrapper
- SaslWrappingConduit - Class in org.xnio.sasl
- SaslWrappingConduit(MessageSinkConduit, SaslWrapper) - Constructor for class org.xnio.sasl.SaslWrappingConduit
- SECURE - Static variable in class org.xnio.Options
-
Determine whether the channel is encrypted, or employs some other level of security.
- secureBufferPool(Pool<ByteBuffer>) - Static method in class org.xnio.Buffers
-
A byte buffer pool which zeroes the content of the buffer before re-pooling it.
- send(ByteBuffer) - Method in class org.xnio.channels.AssembledMessageChannel
- send(ByteBuffer) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Send a complete message.
- send(ByteBuffer) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- send(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
- send(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- send(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSinkConduit
- send(ByteBuffer) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- send(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedMessageSinkConduit
- send(ByteBuffer) - Method in class org.xnio.sasl.SaslUnwrappingConduit
- send(ByteBuffer) - Method in class org.xnio.sasl.SaslWrappingConduit
- send(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
- send(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Send a complete message.
- send(ByteBuffer[]) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- send(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- send(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
- send(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.Send a complete message.
- send(ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSinkConduit
- send(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedMessageSinkConduit
- send(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslUnwrappingConduit
- send(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslWrappingConduit
- SEND_BUFFER - Static variable in class org.xnio.Options
-
The send buffer size.
- sendBlocking(C, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking send on a message channel.
- sendBlocking(C, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking gathering send on a message channel.
- sendBlocking(C, ByteBuffer[], int, int, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking gathering send on a message channel with a timeout.
- sendBlocking(C, ByteBuffer, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking send on a message channel with a timeout.
- sendFinal(ByteBuffer) - Method in class org.xnio.channels.AssembledMessageChannel
- sendFinal(ByteBuffer) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- sendFinal(ByteBuffer) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSinkConduit
- sendFinal(ByteBuffer) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedMessageSinkConduit
- sendFinal(ByteBuffer) - Method in class org.xnio.sasl.SaslUnwrappingConduit
- sendFinal(ByteBuffer) - Method in class org.xnio.sasl.SaslWrappingConduit
- sendFinal(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
- sendFinal(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- sendFinal(ByteBuffer[]) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- sendFinal(ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSinkConduit
- sendFinal(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedMessageSinkConduit
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslUnwrappingConduit
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslWrappingConduit
- sendFinalBasic(MessageSinkConduit, ByteBuffer) - Static method in class org.xnio.conduits.Conduits
-
Writes a message to the conduit, and terminates writes if the send was successfully.
- sendFinalBasic(MessageSinkConduit, ByteBuffer[], int, int) - Static method in class org.xnio.conduits.Conduits
-
Writes a message to the conduit, and terminates writes if the send was successfully.
- sendingChannelListener(Pooled<ByteBuffer>, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A sending channel listener.
- sendTo(SocketAddress, ByteBuffer) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a buffer to a destination.
- sendTo(SocketAddress, ByteBuffer[]) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a message with data from multiple buffers to a destination.
- sendTo(SocketAddress, ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a message with data from multiple buffers to a destination.
- sequence(Class<?>, String, Class<T>) - Static method in class org.xnio.Option
-
Create an option with a sequence type.
- Sequence<T> - Class in org.xnio
-
An immutable sequence of elements.
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.AcceptListenerSettable.Setter
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.CloseListenerSettable.Setter
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.ReadListenerSettable.Setter
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.WriteListenerSettable.Setter
- set(ChannelListener<? super T>) - Method in interface org.xnio.ChannelListener.Setter
-
Set the listener, or
null
to ignore the associated event type. - set(ChannelListener<? super T>) - Method in class org.xnio.ChannelListener.SimpleSetter
-
Set the listener, or
null
to ignore the associated event type. - set(Option<Boolean>, boolean) - Method in class org.xnio.OptionMap.Builder
-
Set a boolean value for a Boolean key.
- set(Option<Integer>, int) - Method in class org.xnio.OptionMap.Builder
-
Set an int value for an Integer key.
- set(Option<Long>, long) - Method in class org.xnio.OptionMap.Builder
-
Set a long value for a Long key.
- set(Option<T>, T) - Method in class org.xnio.OptionMap.Builder
-
Set a key-value pair.
- setAcceptListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.AcceptListenerSettable
-
Set the accept listener.
- setAcceptListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the accept listener for a channel (type-safe).
- setBindAddressConfigurations(CidrAddressTable<InetSocketAddress>) - Method in class org.xnio.XnioWorker.Builder
- setBuilder() - Static method in class org.xnio.Option
-
Create a builder for an immutable option set.
- setCancelled() - Method in class org.xnio.AbstractIoFuture
-
Acknowledge the cancellation of this operation.
- setCancelled() - Method in class org.xnio.FutureResult
-
Acknowledge the cancellation of this operation.
- setCancelled() - Method in interface org.xnio.Result
-
Acknowledge the cancellation of this operation.
- setCancelled() - Method in class org.xnio.TranslatingResult
- setClosed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Set both the channel read and write shut down flags.
- setCloseListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.CloseListenerSettable
-
Set the close listener.
- setCloseListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- setCloseListener(ChannelListener<? super EmptyStreamSourceChannel>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- setCloseListener(ChannelListener<? super FixedLengthStreamSinkChannel>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- setCloseListener(ChannelListener<? super FixedLengthStreamSourceChannel>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- setCloseListener(ChannelListener<? super NullStreamSinkChannel>) - Method in class org.xnio.channels.NullStreamSinkChannel
- setCloseListener(ChannelListener<? super PushBackStreamChannel>) - Method in class org.xnio.channels.PushBackStreamChannel
- setCloseListener(ChannelListener<? super SplitStreamSinkChannel>) - Method in class org.xnio.channels.SplitStreamSinkChannel
- setCloseListener(ChannelListener<? super SplitStreamSourceChannel>) - Method in class org.xnio.channels.SplitStreamSourceChannel
- setCloseListener(ChannelListener<? super ConduitReadableMessageChannel>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- setCloseListener(ChannelListener<? super ConduitStreamSinkChannel>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- setCloseListener(ChannelListener<? super ConduitStreamSourceChannel>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- setCloseListener(ChannelListener<? super ConduitWritableMessageChannel>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- setCloseListener(ChannelListener<? super MessageConnection>) - Method in class org.xnio.MessageConnection
- setCloseListener(ChannelListener<? super StreamConnection>) - Method in class org.xnio.StreamConnection
- setCloseListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the close listener for a channel (type-safe).
- setConduit(MessageSinkConduit) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Set the underlying conduit for this channel.
- setConduit(MessageSourceConduit) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Set the underlying conduit for this channel.
- setConduit(StreamSinkConduit) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Set the underlying conduit for this channel.
- setConduit(StreamSourceConduit) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Set the underlying conduit for this channel.
- setCoreWorkerPoolSize(int) - Method in class org.xnio.XnioWorker.Builder
- setDaemon(boolean) - Method in class org.xnio.XnioWorker.Builder
- setDestinationAddress(SocketAddress) - Method in class org.xnio.channels.SocketAddressBuffer
-
Set the destination address.
- setException(IOException) - Method in class org.xnio.AbstractIoFuture
-
Set the exception for this operation.
- setException(IOException) - Method in class org.xnio.FutureResult
-
Set the exception for this operation.
- setException(IOException) - Method in interface org.xnio.Result
-
Set the exception for this operation.
- setException(IOException) - Method in class org.xnio.TranslatingResult
- setExternalExecutorService(ExecutorService) - Method in class org.xnio.XnioWorker.Builder
- setMaxWorkerPoolSize(int) - Method in class org.xnio.XnioWorker.Builder
- setOption(Option<T>, T) - Method in class org.xnio.channels.AssembledChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.AssembledMessageChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.AssembledStreamChannel
- setOption(Option<T>, T) - Method in interface org.xnio.channels.Configurable
-
Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.NullStreamSinkChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.PushBackStreamChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.SplitStreamSinkChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.SplitStreamSourceChannel
- setOption(Option<T>, T) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- setOption(Option<T>, T) - Method in class org.xnio.Connection
- setOption(Option<T>, T) - Method in class org.xnio.ssl.JsseSslConnection
-
Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.XnioWorker
- setReadListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.ReadListenerSettable
-
Set the read listener.
- setReadListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- setReadListener(ChannelListener<? super EmptyStreamSourceChannel>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- setReadListener(ChannelListener<? super FixedLengthStreamSourceChannel>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- setReadListener(ChannelListener<? super PushBackStreamChannel>) - Method in class org.xnio.channels.PushBackStreamChannel
- setReadListener(ChannelListener<? super SplitStreamSourceChannel>) - Method in class org.xnio.channels.SplitStreamSourceChannel
- setReadListener(ChannelListener<? super ConduitReadableMessageChannel>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- setReadListener(ChannelListener<? super ConduitStreamSourceChannel>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- setReadListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the read listener for a channel (type-safe).
- setReadReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel is definitely immediately readable, regardless of the underlying channel state.
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.AbstractSourceConduit
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- setReadReadyHandler(ReadReadyHandler) - Method in interface org.xnio.conduits.SourceConduit
-
Set the handler which should receive readiness notifications.
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- setReadRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel will not be readable until the write handler is called.
- setReadShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Set the channel read shut down flag.
- setReadTimeout(long, TimeUnit) - Method in class org.xnio.channels.BlockingByteChannel
-
Set the read timeout.
- setReadTimeout(long, TimeUnit) - Method in class org.xnio.channels.BlockingReadableByteChannel
-
Set the read timeout.
- setReadTimeout(long, TimeUnit) - Method in class org.xnio.streams.BufferedChannelInputStream
-
Set the read timeout.
- setReadTimeout(long, TimeUnit) - Method in class org.xnio.streams.ChannelInputStream
-
Set the read timeout.
- setResult(T) - Method in class org.xnio.AbstractIoFuture
-
Set the result for this operation.
- setResult(T) - Method in class org.xnio.FutureResult
-
Set the result for this operation.
- setResult(T) - Method in interface org.xnio.Result
-
Set the result for this operation.
- setResult(T) - Method in class org.xnio.TranslatingResult
- setSequence(Option<Sequence<Boolean>>, boolean...) - Method in class org.xnio.OptionMap.Builder
-
Set boolean values for an Boolean sequence key.
- setSequence(Option<Sequence<Integer>>, int...) - Method in class org.xnio.OptionMap.Builder
-
Set int values for an Integer sequence key.
- setSequence(Option<Sequence<Long>>, long...) - Method in class org.xnio.OptionMap.Builder
-
Set long values for a Long sequence key.
- setSequence(Option<Sequence<T>>, T...) - Method in class org.xnio.OptionMap.Builder
-
Set a key-value pair, where the value is a sequence type.
- setSinkConduit(MessageSinkConduit) - Method in class org.xnio.MessageConnection
- setSinkConduit(StreamSinkConduit) - Method in class org.xnio.StreamConnection
-
Set the sink conduit for this channel.
- setSourceAddress(SocketAddress) - Method in class org.xnio.channels.SocketAddressBuffer
-
Set the source address.
- setSourceConduit(MessageSourceConduit) - Method in class org.xnio.MessageConnection
- setSourceConduit(StreamSourceConduit) - Method in class org.xnio.StreamConnection
-
Set the source conduit for this channel.
- Setter(AcceptListenerSettable<C>) - Constructor for class org.xnio.channels.AcceptListenerSettable.Setter
-
Construct a new instance.
- Setter(CloseListenerSettable<C>) - Constructor for class org.xnio.channels.CloseListenerSettable.Setter
-
Construct a new instance.
- Setter(ReadListenerSettable<C>) - Constructor for class org.xnio.channels.ReadListenerSettable.Setter
-
Construct a new instance.
- Setter(WriteListenerSettable<C>) - Constructor for class org.xnio.channels.WriteListenerSettable.Setter
-
Construct a new instance.
- setTerminationTask(Runnable) - Method in class org.xnio.XnioWorker.Builder
- setThreadGroup(ThreadGroup) - Method in class org.xnio.XnioWorker.Builder
- setWorkerIoThreads(int) - Method in class org.xnio.XnioWorker.Builder
- setWorkerKeepAlive(int) - Method in class org.xnio.XnioWorker.Builder
- setWorkerName(String) - Method in class org.xnio.XnioWorker.Builder
- setWorkerStackSize(long) - Method in class org.xnio.XnioWorker.Builder
- setWriteListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- setWriteListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.WriteListenerSettable
-
Set the write listener.
- setWriteListener(ChannelListener<? super FixedLengthStreamSinkChannel>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- setWriteListener(ChannelListener<? super NullStreamSinkChannel>) - Method in class org.xnio.channels.NullStreamSinkChannel
- setWriteListener(ChannelListener<? super SplitStreamSinkChannel>) - Method in class org.xnio.channels.SplitStreamSinkChannel
- setWriteListener(ChannelListener<? super ConduitStreamSinkChannel>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- setWriteListener(ChannelListener<? super ConduitWritableMessageChannel>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- setWriteListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the write listener for a channel (type-safe).
- setWriteReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel is definitely immediately writable, regardless of the underlying channel state.
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.AbstractSinkConduit
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.NullStreamSinkConduit
- setWriteReadyHandler(WriteReadyHandler) - Method in interface org.xnio.conduits.SinkConduit
-
Set the handler which should receive readiness notifications.
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- setWriteRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that the channel will not be writable until the read handler is called.
- setWriteShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Set the channel write shut down flag.
- setWriteTimeout(long, TimeUnit) - Method in class org.xnio.channels.BlockingByteChannel
-
Set the write timeout.
- setWriteTimeout(long, TimeUnit) - Method in class org.xnio.channels.BlockingWritableByteChannel
-
Set the write timeout.
- setWriteTimeout(long, TimeUnit) - Method in class org.xnio.streams.ChannelOutputStream
-
Set the write timeout.
- shortFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed big-endian short value from a byte array.
- shortFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed little-endian short value from a byte array.
- shutdown() - Method in class org.xnio.XnioWorker
-
Shut down this worker.
- shutdownNow() - Method in class org.xnio.XnioWorker
-
Immediately terminate the worker.
- shutdownReads() - Method in class org.xnio.channels.AssembledMessageChannel
- shutdownReads() - Method in class org.xnio.channels.AssembledStreamChannel
- shutdownReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- shutdownReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- shutdownReads() - Method in class org.xnio.channels.PushBackStreamChannel
- shutdownReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
- shutdownReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Places this readable channel at "end of stream".
- shutdownReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Perform the read shutdown action if it hasn't been performed already.
- shutdownReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- shutdownReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- shutdownReadsAction(boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- shutdownReadsAction(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.The action to perform when reads are shut down.
- shutDownTaskPool() - Method in class org.xnio.XnioWorker
-
Initiate shutdown of the task thread pool.
- shutDownTaskPoolNow() - Method in class org.xnio.XnioWorker
-
Shut down the task thread pool immediately and return its pending tasks.
- shutdownWrites() - Method in class org.xnio.channels.AssembledMessageChannel
- shutdownWrites() - Method in class org.xnio.channels.AssembledStreamChannel
- shutdownWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- shutdownWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
- shutdownWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
- shutdownWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Indicate that writing is complete for this channel.
- shutdownWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Perform the write shutdown action if it hasn't been performed already.
- shutdownWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- shutdownWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- shutdownWritesAction() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.The action to perform when writes are requested to be shut down.
- shutdownWritesBlocking(SuspendableWriteChannel) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write shutdown on a writable channel.
- shutdownWritesBlocking(SuspendableWriteChannel, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write shutdown on a writable channel.
- shutdownWritesComplete(boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
Deprecated.
- shutdownWritesComplete(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Notification that the channel has successfully flushed after having shut down writes.
- simple(Class<?>, String, Class<T>) - Static method in class org.xnio.Option
-
Create an option with a simple type.
- SimpleAcceptingChannel<C> - Interface in org.xnio.channels
-
A channel which can accept connections.
- SimpleSetter() - Constructor for class org.xnio.ChannelListener.SimpleSetter
- SinkConduit - Interface in org.xnio.conduits
-
A conduit which is a target or output for data.
- size() - Method in class java.nio.channels.FileChannel
- size() - Method in class org.xnio.OptionMap
-
Get the number of options stored in this map.
- size() - Method in class org.xnio.Sequence
-
Return the number of elements in this sequence.
- skip(long) - Method in class org.xnio.streams.BufferedChannelInputStream
-
Skip bytes in the stream.
- skip(long) - Method in class org.xnio.streams.BufferPipeInputStream
- skip(long) - Method in class org.xnio.streams.ChannelInputStream
-
Skip bytes in the stream.
- skip(long) - Method in class org.xnio.streams.LimitedInputStream
- skip(long) - Method in class org.xnio.streams.ReaderInputStream
- skip(T, int) - Static method in class org.xnio.Buffers
-
Advance a buffer's position relative to its current position.
- slice(ByteBuffer, int) - Static method in class org.xnio.Buffers
-
Slice the buffer.
- slice(CharBuffer, int) - Static method in class org.xnio.Buffers
-
Slice the buffer.
- slice(IntBuffer, int) - Static method in class org.xnio.Buffers
-
Slice the buffer.
- slice(LongBuffer, int) - Static method in class org.xnio.Buffers
-
Slice the buffer.
- slice(ShortBuffer, int) - Static method in class org.xnio.Buffers
-
Slice the buffer.
- sliceAllocator(ByteBuffer) - Static method in class org.xnio.Buffers
-
A buffer allocator which allocates slices off of the given buffer.
- SMALL_DIRECT - Static variable in class org.xnio.ByteBufferPool
-
The small direct buffer pool.
- SMALL_HEAP - Static variable in class org.xnio.ByteBufferPool
-
The small heap buffer pool.
- SMALL_SIZE - Static variable in class org.xnio.ByteBufferPool
-
The size of small buffers.
- SocketAddressBuffer - Class in org.xnio.channels
-
A buffer for source and destination addresses.
- SocketAddressBuffer() - Constructor for class org.xnio.channels.SocketAddressBuffer
-
Construct a new instance.
- socketBufferTooSmall() - Method in class org.xnio._private.Messages_$logger
- socketBufferTooSmall() - Method in interface org.xnio._private.Messages
- socketBufferTooSmall$str() - Method in class org.xnio._private.Messages_$logger
- SourceConduit - Interface in org.xnio.conduits
- SPLIT_READ_WRITE_THREADS - Static variable in class org.xnio.Options
-
Specify whether read and write operations should be split among separate threads.
- SplitStreamSinkChannel - Class in org.xnio.channels
-
A half-duplex (write side) wrapper for a full-duplex channel.
- SplitStreamSinkChannel(StreamSinkChannel) - Constructor for class org.xnio.channels.SplitStreamSinkChannel
-
Construct a new instance which does not delegate configuration.
- SplitStreamSinkChannel(StreamSinkChannel, boolean) - Constructor for class org.xnio.channels.SplitStreamSinkChannel
-
Construct a new instance.
- SplitStreamSourceChannel - Class in org.xnio.channels
-
A half-duplex (read side) wrapper for a full-duplex channel.
- SplitStreamSourceChannel(StreamSourceChannel) - Constructor for class org.xnio.channels.SplitStreamSourceChannel
-
Construct a new instance which doesn't delegate configuration.
- SplitStreamSourceChannel(StreamSourceChannel, boolean) - Constructor for class org.xnio.channels.SplitStreamSourceChannel
-
Construct a new instance.
- SSL_APPLICATION_BUFFER_REGION_SIZE - Static variable in class org.xnio.Options
-
The size of the allocation region to use for SSL application buffers.
- SSL_APPLICATION_BUFFER_SIZE - Static variable in class org.xnio.Options
-
The application buffer size for SSL.
- SSL_CLIENT_AUTH_MODE - Static variable in class org.xnio.Options
-
Specify the SSL client authentication mode.
- SSL_CLIENT_SESSION_CACHE_SIZE - Static variable in class org.xnio.Options
-
The size of the SSL client session cache.
- SSL_CLIENT_SESSION_TIMEOUT - Static variable in class org.xnio.Options
-
The SSL client session timeout (in seconds).
- SSL_ENABLE_SESSION_CREATION - Static variable in class org.xnio.Options
-
Enable or disable session creation for an SSL connection.
- SSL_ENABLED - Static variable in class org.xnio.Options
-
Specify whether SSL should be enabled.
- SSL_ENABLED_CIPHER_SUITES - Static variable in class org.xnio.Options
-
Specify the cipher suites for an SSL/TLS session.
- SSL_ENABLED_PROTOCOLS - Static variable in class org.xnio.Options
-
Specify the enabled protocols for an SSL/TLS session.
- SSL_JSSE_KEY_MANAGER_CLASSES - Static variable in class org.xnio.Options
-
The possible key manager classes to use for a JSSE SSL context.
- SSL_JSSE_TRUST_MANAGER_CLASSES - Static variable in class org.xnio.Options
-
The possible trust store classes to use for a JSSE SSL context.
- SSL_NON_BLOCKING_KEY_MANAGER - Static variable in class org.xnio.Options
-
Hint to the SSL engine that the key manager implementation(s) is/are non-blocking, so they can be executed in the I/O thread, possibly improving performance by decreasing latency.
- SSL_NON_BLOCKING_TRUST_MANAGER - Static variable in class org.xnio.Options
-
Hint to the SSL engine that the trust manager implementation(s) is/are non-blocking, so they can be executed in the I/O thread, possibly improving performance by decreasing latency.
- SSL_PACKET_BUFFER_REGION_SIZE - Static variable in class org.xnio.Options
-
The size of the allocation region to use for SSL packet buffers.
- SSL_PACKET_BUFFER_SIZE - Static variable in class org.xnio.Options
-
The packet buffer size for SSL.
- SSL_PEER_HOST_NAME - Static variable in class org.xnio.Options
-
Specify the (non-authoritative) name of the peer host to use for the purposes of session reuse, as well as for the use of certain cipher suites (such as Kerberos).
- SSL_PEER_PORT - Static variable in class org.xnio.Options
-
Specify the (non-authoritative) port number of the peer port number to use for the purposes of session reuse, as well as for the use of certain cipher suites.
- SSL_PROTOCOL - Static variable in class org.xnio.Options
-
Specify the protocol name for an SSL context.
- SSL_PROVIDER - Static variable in class org.xnio.Options
-
Specify the requested provider for an SSL/TLS session.
- SSL_RNG_OPTIONS - Static variable in class org.xnio.Options
-
The configuration of a secure RNG for SSL usage.
- SSL_SERVER_SESSION_CACHE_SIZE - Static variable in class org.xnio.Options
-
The size of the SSL server session cache.
- SSL_SERVER_SESSION_TIMEOUT - Static variable in class org.xnio.Options
-
The SSL server session timeout (in seconds).
- SSL_STARTTLS - Static variable in class org.xnio.Options
-
Specify whether to use STARTTLS mode (in which a connection starts clear and switches to TLS on demand).
- SSL_SUPPORTED_CIPHER_SUITES - Static variable in class org.xnio.Options
-
Get the supported cipher suites for an SSL/TLS session.
- SSL_SUPPORTED_PROTOCOLS - Static variable in class org.xnio.Options
-
Get the supported protocols for an SSL/TLS session.
- SSL_USE_CLIENT_MODE - Static variable in class org.xnio.Options
-
Specify whether SSL conversations should be in client or server mode.
- SslChannel - Interface in org.xnio.channels
-
A channel which can use SSL/TLS to negotiate a security layer.
- SslClientAuthMode - Enum in org.xnio
-
The desired SSL client authentication mode for SSL channels in server mode.
- SslConnection - Class in org.xnio.ssl
-
A stream connection which can use SSL/TLS to negotiate a security layer.
- SslConnection(XnioIoThread) - Constructor for class org.xnio.ssl.SslConnection
-
Construct a new instance.
- sslContext - Variable in class org.xnio.ssl.XnioSsl
-
The SSL context for this instance.
- STACK_SIZE - Static variable in class org.xnio.Options
-
The stack size (in bytes) to attempt to use for worker threads.
- startHandshake() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
- startHandshake() - Method in class org.xnio.channels.AssembledSslChannel
- startHandshake() - Method in interface org.xnio.channels.SslChannel
-
Start or restart the SSL/TLS handshake.
- startHandshake() - Method in class org.xnio.ssl.JsseSslConnection
- startHandshake() - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Start or restart the SSL/TLS handshake.
- startHandshake() - Method in class org.xnio.ssl.SslConnection
-
Start or restart the SSL/TLS handshake.
- startsWith(char) - Method in class org.xnio.ByteString
- startsWith(String) - Method in class org.xnio.ByteString
- startsWith(ByteString) - Method in class org.xnio.ByteString
- startsWithIgnoreCase(char) - Method in class org.xnio.ByteString
- startsWithIgnoreCase(String) - Method in class org.xnio.ByteString
- startsWithIgnoreCase(ByteString) - Method in class org.xnio.ByteString
- StreamChannel - Interface in org.xnio.channels
-
A stream channel.
- streamClosed() - Method in class org.xnio._private.Messages_$logger
- streamClosed() - Method in interface org.xnio._private.Messages
- streamClosed$str() - Method in class org.xnio._private.Messages_$logger
- StreamConnection - Class in org.xnio
-
A connection between peers.
- StreamConnection(XnioIoThread) - Constructor for class org.xnio.StreamConnection
-
Construct a new instance.
- Streams - Class in org.xnio.streams
-
Stream utility class.
- StreamSinkChannel - Interface in org.xnio.channels
-
A stream sink channel.
- StreamSinkChannelWrappingConduit - Class in org.xnio.conduits
-
A conduit which wraps a channel, for compatibility.
- StreamSinkChannelWrappingConduit(StreamSinkChannel) - Constructor for class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
Construct a new instance.
- StreamSinkConduit - Interface in org.xnio.conduits
-
A sink (writable) conduit for byte streams.
- StreamSourceChannel - Interface in org.xnio.channels
-
A stream source channel.
- StreamSourceChannelWrappingConduit - Class in org.xnio.conduits
-
A conduit which wraps a channel, for compatibility.
- StreamSourceChannelWrappingConduit(StreamSourceChannel) - Constructor for class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
Construct a new instance.
- StreamSourceConduit - Interface in org.xnio.conduits
- subSequence(int, int) - Method in class org.xnio.ByteString
- substring(int) - Method in class org.xnio.ByteString
-
Get the substring of this string starting at the given offset.
- substring(int, int) - Method in class org.xnio.ByteString
-
Get the substring of this string starting at the given offset.
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledMessageChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledStreamChannel
- supportsOption(Option<?>) - Method in interface org.xnio.channels.Configurable
-
Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.NullStreamSinkChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.PushBackStreamChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.SplitStreamSinkChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.SplitStreamSourceChannel
- supportsOption(Option<?>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- supportsOption(Option<?>) - Method in class org.xnio.Connection
- supportsOption(Option<?>) - Method in class org.xnio.ssl.JsseSslConnection
-
Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.ssl.JsseSslStreamConnection
-
Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.XnioWorker
- SuspendableAcceptChannel - Interface in org.xnio.channels
-
A suspendable accept channel.
- SuspendableChannel - Interface in org.xnio.channels
-
A suspendable bidirectional channel.
- SuspendableReadChannel - Interface in org.xnio.channels
-
A suspendable readable channel.
- SuspendableWriteChannel - Interface in org.xnio.channels
-
A suspendable writable channel.
- suspendAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.channels.AssembledMessageChannel
- suspendReads() - Method in class org.xnio.channels.AssembledStreamChannel
- suspendReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- suspendReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- suspendReads() - Method in class org.xnio.channels.PushBackStreamChannel
- suspendReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
- suspendReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.conduits.AbstractSourceConduit
- suspendReads() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- suspendReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- suspendReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- suspendReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- suspendReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- suspendReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that calling the conduit's
ReadReadyHandler
should be suspended. - suspendReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- suspendWrites() - Method in class org.xnio.channels.AssembledMessageChannel
- suspendWrites() - Method in class org.xnio.channels.AssembledStreamChannel
- suspendWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- suspendWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
- suspendWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
- suspendWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Suspend further write notifications on this channel.
- suspendWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Suspend further write notifications on this channel.
- suspendWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
- suspendWrites() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- suspendWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- suspendWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- suspendWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- suspendWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
- suspendWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Indicate that calling the conduit's
WriteReadyHandler
should be suspended. - suspendWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- SynchronizedMessageSinkConduit - Class in org.xnio.conduits
-
A synchronized message sink conduit.
- SynchronizedMessageSinkConduit(MessageSinkConduit) - Constructor for class org.xnio.conduits.SynchronizedMessageSinkConduit
-
Construct a new instance.
- SynchronizedMessageSinkConduit(MessageSinkConduit, Object) - Constructor for class org.xnio.conduits.SynchronizedMessageSinkConduit
-
Construct a new instance.
- SynchronizedMessageSourceConduit - Class in org.xnio.conduits
-
A synchronized message source conduit.
- SynchronizedMessageSourceConduit(MessageSourceConduit) - Constructor for class org.xnio.conduits.SynchronizedMessageSourceConduit
-
Construct a new instance.
- SynchronizedMessageSourceConduit(MessageSourceConduit, Object) - Constructor for class org.xnio.conduits.SynchronizedMessageSourceConduit
-
Construct a new instance.
- SynchronizedStreamSinkConduit - Class in org.xnio.conduits
-
A synchronized stream sink conduit.
- SynchronizedStreamSinkConduit(StreamSinkConduit) - Constructor for class org.xnio.conduits.SynchronizedStreamSinkConduit
-
Construct a new instance.
- SynchronizedStreamSinkConduit(StreamSinkConduit, Object) - Constructor for class org.xnio.conduits.SynchronizedStreamSinkConduit
-
Construct a new instance.
- SynchronizedStreamSourceConduit - Class in org.xnio.conduits
-
A synchronized stream source conduit.
- SynchronizedStreamSourceConduit(StreamSourceConduit) - Constructor for class org.xnio.conduits.SynchronizedStreamSourceConduit
-
Construct a new instance.
- SynchronizedStreamSourceConduit(StreamSourceConduit, Object) - Constructor for class org.xnio.conduits.SynchronizedStreamSourceConduit
-
Construct a new instance.
T
- take(ByteBuffer) - Static method in class org.xnio.Buffers
-
Take all of the remaining bytes from the buffer and return them in an array.
- take(ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Take all of the remaining bytes from the buffers and return them in an array.
- take(ByteBuffer, int) - Static method in class org.xnio.Buffers
-
Take a certain number of bytes from the buffer and return them in an array.
- take(CharBuffer) - Static method in class org.xnio.Buffers
-
Take all of the remaining chars from the buffer and return them in an array.
- take(CharBuffer, int) - Static method in class org.xnio.Buffers
-
Take a certain number of chars from the buffer and return them in an array.
- take(IntBuffer) - Static method in class org.xnio.Buffers
-
Take all of the remaining ints from the buffer and return them in an array.
- take(IntBuffer, int) - Static method in class org.xnio.Buffers
-
Take a certain number of ints from the buffer and return them in an array.
- take(LongBuffer) - Static method in class org.xnio.Buffers
-
Take all of the remaining longs from the buffer and return them in an array.
- take(LongBuffer, int) - Static method in class org.xnio.Buffers
-
Take a certain number of longs from the buffer and return them in an array.
- take(ShortBuffer) - Static method in class org.xnio.Buffers
-
Take all of the remaining shorts from the buffer and return them in an array.
- take(ShortBuffer, int) - Static method in class org.xnio.Buffers
-
Take a certain number of shorts from the buffer and return them in an array.
- taskPoolTerminated() - Method in class org.xnio.XnioWorker
-
Callback to indicate that the task thread pool has terminated.
- TCP_NODELAY - Static variable in class org.xnio.Options
-
Configure a TCP socket to disable Nagle's algorithm.
- TCP_OOB_INLINE - Static variable in class org.xnio.Options
-
Configure a TCP socket to receive out-of-band data alongside regular data.
- terminated() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
- terminated() - Method in class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
- terminated() - Method in interface org.xnio.conduits.TerminateHandler
-
Indicate that a previous shutdown request has successfully resulted in termination.
- terminated() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
- TerminateHandler - Interface in org.xnio.conduits
-
The base ready handler type, which can forward termination requests as well as notifications of termination completion.
- TerminateHandler.ChannelListenerHandler<C> - Class in org.xnio.conduits
-
A terminate handler which calls a channel listener on termination notification.
- TerminateHandler.ReadyTask - Class in org.xnio.conduits
-
A runnable task which invokes the
TerminateHandler.terminated()
method of the given handler. - terminateReads() - Method in class org.xnio.conduits.AbstractSourceConduit
- terminateReads() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- terminateReads() - Method in class org.xnio.conduits.BufferedStreamSourceConduit
- terminateReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- terminateReads() - Method in class org.xnio.conduits.FramingMessageSourceConduit
- terminateReads() - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- terminateReads() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- terminateReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that no more data will be read from this conduit.
- terminateReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- terminateWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.FramingMessageSinkConduit
- terminateWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
- terminateWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Signal that no more write data is forthcoming.
- terminateWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- thisTyped() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Get this channel, cast to the implemented channel type.
- thread - Variable in class org.xnio.Connection
- THREAD_DAEMON - Static variable in class org.xnio.Options
-
Specify whether worker threads should be daemon threads.
- THREAD_PRIORITY - Static variable in class org.xnio.Options
-
The thread priority for newly created worker threads.
- toArray() - Method in class org.xnio.Sequence
-
Get a copy of the values array.
- toInt() - Method in class org.xnio.ByteString
-
Get the unsigned
int
value of this string. - toInt(int) - Method in class org.xnio.ByteString
-
Get the unsigned
int
value of this string. - toLong() - Method in class org.xnio.ByteString
-
Get the unsigned
long
value of this string. - toLong(int) - Method in class org.xnio.ByteString
-
Get the unsigned
long
value of this string. - toString() - Method in class org.xnio.ByteString
-
Decode this byte string as a Latin-1 string.
- toString() - Method in class org.xnio.ChannelListener.SimpleSetter
- toString() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- toString() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- toString() - Method in class org.xnio.LocalSocketAddress
-
Get the string representation of this socket address (its name).
- toString() - Method in class org.xnio.Option
-
Get a human-readable string representation of this object.
- toString() - Method in class org.xnio.OptionMap
- toString() - Method in class org.xnio.Property
-
Get the
String
representation of this property. - toString() - Method in enum org.xnio.sasl.SaslQop
-
Get the human-readable string representation of this SASL QOP value.
- toString() - Method in enum org.xnio.sasl.SaslStrength
-
Returns the human-readable reprentation of this Strength value.
- toString() - Method in class org.xnio.streams.ReaderInputStream
-
Get a string representation of this object.
- toString() - Method in class org.xnio.streams.WriterOutputStream
-
Get the string representation of this object.
- toString() - Method in class org.xnio.Xnio
-
Get a string representation of this XNIO provider.
- toString(String) - Method in class org.xnio.ByteString
-
Convert this byte string to a standard string.
- toUtf8String() - Method in class org.xnio.ByteString
-
Decode this byte string as a UTF-8 string.
- transfer(ReadableByteChannel, long, ByteBuffer, WritableByteChannel) - Static method in class org.xnio.IoUtils
-
Platform-independent channel-to-channel transfer method.
- transfer(ReadableByteChannel, long, ByteBuffer, StreamSinkConduit) - Static method in class org.xnio.conduits.Conduits
-
Platform-independent channel-to-channel transfer method.
- transfer(StreamSourceConduit, long, ByteBuffer, WritableByteChannel) - Static method in class org.xnio.conduits.Conduits
-
Platform-independent channel-to-channel transfer method.
- transferBlocking(FileChannel, StreamSourceChannel, long, long) - Static method in class org.xnio.channels.Channels
-
Transfer bytes between two channels efficiently, blocking if necessary.
- transferBlocking(StreamSinkChannel, FileChannel, long, long) - Static method in class org.xnio.channels.Channels
-
Transfer bytes between two channels efficiently, blocking if necessary.
- transferBlocking(StreamSinkChannel, StreamSourceChannel, ByteBuffer, long) - Static method in class org.xnio.channels.Channels
-
Transfer bytes between two channels efficiently, blocking if necessary.
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.AssembledStreamChannel
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.NullStreamSinkChannel
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.SplitStreamSinkChannel
- transferFrom(FileChannel, long, long) - Method in interface org.xnio.channels.StreamSinkChannel
-
Transfer bytes into this channel from the given file.
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.NullStreamSinkConduit
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- transferFrom(FileChannel, long, long) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Transfer bytes into this conduit from the given file.
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- transferFrom(ReadableByteChannel, long, long) - Method in class java.nio.channels.FileChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in interface org.xnio.channels.StreamSinkChannel
-
Transfers bytes from the given channel source.
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Transfers bytes from the given channel source.
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.AssembledStreamChannel
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.PushBackStreamChannel
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.SplitStreamSourceChannel
- transferTo(long, long, FileChannel) - Method in interface org.xnio.channels.StreamSourceChannel
-
Transfers bytes into the given file from this channel.
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.MessageStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- transferTo(long, long, FileChannel) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Transfers bytes into the given file from this channel.
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.SynchronizedStreamSourceConduit
- transferTo(long, long, WritableByteChannel) - Method in class java.nio.channels.FileChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.AssembledStreamChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.EmptyStreamSourceChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.PushBackStreamChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.SplitStreamSourceChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in interface org.xnio.channels.StreamSourceChannel
-
Transfers bytes into the given channel target.
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.MessageStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Transfers bytes into the given channel target.
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.SynchronizedStreamSourceConduit
- translate(T) - Method in class org.xnio.TranslatingResult
- TranslatingResult<T,
O> - Class in org.xnio -
Abstract base class for
Result
s which translate from one type to another. - TranslatingResult(Result<O>) - Constructor for class org.xnio.TranslatingResult
- TranslatingSuspendableChannel<C,
W> - Class in org.xnio.channels -
Deprecated.This class is deprecated; use conduits instead.
- TranslatingSuspendableChannel(W) - Constructor for class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Construct a new instance.
- truncate(long) - Method in class java.nio.channels.FileChannel
- truncateWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.FramingMessageSinkConduit
- truncateWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
- truncateWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Terminate writes and discard any outstanding write data.
- truncateWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- tryAddReadRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that read requires an external task to complete.
- tryAddWriteRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate that write requires an external task to complete.
- tryAppendTo(int, ByteBuffer) - Method in class org.xnio.ByteString
-
Append as many bytes as possible to a byte buffer.
- tryLock() - Method in class java.nio.channels.FileChannel
- tryLock(long, long, boolean) - Method in class java.nio.channels.FileChannel
- trySkip(Buffer[], int, int, long) - Static method in class org.xnio.Buffers
-
Attempt to advance a series of buffers' overall position relative to its current position.
- trySkip(Buffer, int) - Static method in class org.xnio.Buffers
-
Attempt to advance a buffer's position relative to its current position.
- txMsgTooLarge() - Method in class org.xnio._private.Messages_$logger
- txMsgTooLarge() - Method in interface org.xnio._private.Messages
- txMsgTooLarge$str() - Method in class org.xnio._private.Messages_$logger
- type(Class<?>, String, Class<T>) - Static method in class org.xnio.Option
-
Create an option with a class type.
- typeSequence(Class<?>, String, Class<T>) - Static method in class org.xnio.Option
-
Create an option with a sequence-of-types type.
U
- unblock(InetAddress) - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Unblock multicast packets from the given source address that was previously blocked using the
MulticastMessageChannel.Key.block(InetAddress)
method. - unexpectedHandshakeStatus(SSLEngineResult.HandshakeStatus) - Method in class org.xnio._private.Messages_$logger
- unexpectedHandshakeStatus(SSLEngineResult.HandshakeStatus) - Method in interface org.xnio._private.Messages
- unexpectedHandshakeStatus$str() - Method in class org.xnio._private.Messages_$logger
- unexpectedUnwrapResult(SSLEngineResult.Status) - Method in class org.xnio._private.Messages_$logger
- unexpectedUnwrapResult(SSLEngineResult.Status) - Method in interface org.xnio._private.Messages
- unexpectedUnwrapResult$str() - Method in class org.xnio._private.Messages_$logger
- unexpectedWrapResult(SSLEngineResult.Status) - Method in class org.xnio._private.Messages_$logger
- unexpectedWrapResult(SSLEngineResult.Status) - Method in interface org.xnio._private.Messages
- unexpectedWrapResult$str() - Method in class org.xnio._private.Messages_$logger
- unflushedData() - Method in class org.xnio._private.Messages_$logger
- unflushedData() - Method in interface org.xnio._private.Messages
- unflushedData$str() - Method in class org.xnio._private.Messages_$logger
- unget(Pooled<ByteBuffer>) - Method in class org.xnio.channels.PushBackStreamChannel
-
Re-queue the given pooled buffer into this channel.
- unget(T, int) - Static method in class org.xnio.Buffers
-
Rewind a buffer's position relative to its current position.
- unmappableCharacter() - Method in class org.xnio._private.Messages_$logger
- unmappableCharacter() - Method in interface org.xnio._private.Messages
- unmappableCharacter$str() - Method in class org.xnio._private.Messages_$logger
- unsigned(byte) - Static method in class org.xnio.Bits
-
Convert a signed value to unsigned.
- unsigned(int) - Static method in class org.xnio.Bits
-
Convert a signed value to unsigned.
- unsigned(short) - Static method in class org.xnio.Bits
-
Convert a signed value to unsigned.
- unsupported(String) - Method in class org.xnio._private.Messages_$logger
- unsupported(String) - Method in interface org.xnio._private.Messages
- unsupported$str() - Method in class org.xnio._private.Messages_$logger
- UnsupportedOptionException - Exception Class in org.xnio.channels
-
An exception that is thrown when an invalid option is specified for a
Configurable
. - UnsupportedOptionException() - Constructor for exception class org.xnio.channels.UnsupportedOptionException
-
Construct a
UnsupportedOptionException
instance. - UnsupportedOptionException(String) - Constructor for exception class org.xnio.channels.UnsupportedOptionException
-
Construct a
UnsupportedOptionException
instance with the given message. - UnsupportedOptionException(String, Throwable) - Constructor for exception class org.xnio.channels.UnsupportedOptionException
-
Construct a
UnsupportedOptionException
instance with the given message and cause. - UnsupportedOptionException(Throwable) - Constructor for exception class org.xnio.channels.UnsupportedOptionException
-
Construct a
UnsupportedOptionException
instance with the given cause. - unwatchPath(File, FileChangeCallback) - Method in interface org.xnio.FileSystemWatcher
-
Stop watching a path.
- unwrap(byte[]) - Method in class org.xnio.sasl.SaslWrapper
-
Unwrap a message.
- unwrap(byte[], int, int) - Method in class org.xnio.sasl.SaslWrapper
-
Unwrap a message.
- unwrap(Class<T>, Channel) - Static method in class org.xnio.channels.Channels
-
Unwrap a nested channel type.
- unwrap(ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
-
Unwrap a message.
- unwrap(ByteBuffer, ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
-
Unwrap a message.
- unwrap(SaslClient, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Unwrap a message.
- unwrap(SaslClient, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Unwrap a message.
- unwrap(SaslServer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Unwrap a message.
- unwrap(SaslServer, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Unwrap a message.
- unwrapFileChannel(FileChannel) - Method in class org.xnio.Xnio
-
Unwrap an XNIO-wrapped file channel.
- UpgradeFailedException - Exception Class in org.xnio.http
-
Exception that is thrown when a valid HTTP response is received that is not an upgrade or redirect response.
- UpgradeFailedException() - Constructor for exception class org.xnio.http.UpgradeFailedException
-
Constructs a new
UpgradeFailedException
instance. - UpgradeFailedException(String) - Constructor for exception class org.xnio.http.UpgradeFailedException
-
Constructs a new
UpgradeFailedException
instance with an initial message. - UpgradeFailedException(String, Throwable) - Constructor for exception class org.xnio.http.UpgradeFailedException
-
Constructs a new
UpgradeFailedException
instance with an initial message and cause. - UpgradeFailedException(Throwable) - Constructor for exception class org.xnio.http.UpgradeFailedException
-
Constructs a new
UpgradeFailedException
instance with an initial cause. - USE_DIRECT_BUFFERS - Static variable in class org.xnio.Options
-
Specify whether direct buffers should be used for socket communications.
V
- valueOf(String) - Static method in enum org.xnio.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.FileAccess
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.FileChangeEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.IoFuture.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.sasl.SaslQop
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.sasl.SaslStrength
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.xnio.SslClientAuthMode
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.xnio.CompressionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.FileAccess
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.FileChangeEvent.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.IoFuture.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.sasl.SaslQop
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.sasl.SaslStrength
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.xnio.SslClientAuthMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- Version - Class in org.xnio
-
The version class.
- VERSION - Static variable in class org.xnio.Version
W
- WAITING - Enum constant in enum org.xnio.IoFuture.Status
-
The operation is still in progress.
- wakeupAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Deprecated.Users should instead submit
Runnable
tasks to the channel thread when this functionality is needed. - wakeupReads() - Method in class org.xnio.channels.AssembledMessageChannel
- wakeupReads() - Method in class org.xnio.channels.AssembledStreamChannel
- wakeupReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
- wakeupReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
- wakeupReads() - Method in class org.xnio.channels.PushBackStreamChannel
- wakeupReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
- wakeupReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Deprecated.Users should instead submit
Runnable
tasks to the channel thread when this functionality is needed. - wakeupReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
Resume reads
on this channel, and force the read listener to be triggered even if the channel isn't actually readable. - wakeupReads() - Method in class org.xnio.conduits.AbstractSourceConduit
- wakeupReads() - Method in class org.xnio.conduits.AbstractSynchronizedSourceConduit
- wakeupReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
- wakeupReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
- wakeupReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
- wakeupReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
- wakeupReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that the conduit's
ReadReadyHandler
should be invoked immediately, and then again as soon as data can be read without blocking. - wakeupReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
- wakeupWrites() - Method in class org.xnio.channels.AssembledMessageChannel
- wakeupWrites() - Method in class org.xnio.channels.AssembledStreamChannel
- wakeupWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- wakeupWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
- wakeupWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
- wakeupWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Deprecated.Users should instead submit
Runnable
tasks to the channel thread when this functionality is needed. - wakeupWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
Resume writes
on this channel, and force the write listener to be triggered even if the channel isn't actually writable. - wakeupWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
- wakeupWrites() - Method in class org.xnio.conduits.AbstractSynchronizedSinkConduit
- wakeupWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- wakeupWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- wakeupWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
- wakeupWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
- wakeupWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Indicate that the conduit's
WriteReadyHandler
should be invoked immediately, and then again as soon as data can be written without blocking. - wakeupWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- WATCHER_POLL_INTERVAL - Static variable in class org.xnio.Options
-
The poll interval for poll based file system watchers.
- watchPath(File, FileChangeCallback) - Method in interface org.xnio.FileSystemWatcher
-
Watch the given path recursively, and invoke the callback when a change is made.
- WORKER_ACCEPT_THREADS - Static variable in class org.xnio.Options
-
Deprecated.This option is now ignored. All I/O threads are used for accept, except in the case of split read/write threads, in which case only read or write threads will be used as determined by
Options.WORKER_ESTABLISH_WRITING
. - WORKER_ESTABLISH_WRITING - Static variable in class org.xnio.Options
-
Specify whether a server, acceptor, or connector should be attached to write threads.
- WORKER_IO_THREADS - Static variable in class org.xnio.Options
-
Specify the number of I/O threads to create for the worker.
- WORKER_NAME - Static variable in class org.xnio.Options
-
The name to use for a newly created worker.
- WORKER_READ_THREADS - Static variable in class org.xnio.Options
-
Specify the number of I/O threads to devote to reading for split thread channels.
- WORKER_TASK_CORE_THREADS - Static variable in class org.xnio.Options
-
Specify the number of "core" threads for the worker task thread pool.
- WORKER_TASK_KEEPALIVE - Static variable in class org.xnio.Options
-
Specify the number of milliseconds to keep non-core task threads alive.
- WORKER_TASK_LIMIT - Static variable in class org.xnio.Options
-
Specify the maximum number of worker tasks to allow before rejecting.
- WORKER_TASK_MAX_THREADS - Static variable in class org.xnio.Options
-
Specify the maximum number of threads for the worker task thread pool.
- WORKER_WRITE_THREADS - Static variable in class org.xnio.Options
-
Specify the number of I/O threads to devote to writing for split thread channels.
- wrap(byte[]) - Method in class org.xnio.sasl.SaslWrapper
-
Wrap a message.
- wrap(byte[], int, int) - Method in class org.xnio.sasl.SaslWrapper
-
Wrap a message.
- wrap(ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
-
Wrap a message.
- wrap(ByteBuffer, ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
-
Wrap a message.
- wrap(SaslClient, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Wrap a message.
- wrap(SaslClient, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Wrap a message.
- wrap(SaslServer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Wrap a message.
- wrap(SaslServer, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Wrap a message.
- wrapByteChannel(ByteChannel) - Static method in class org.xnio.channels.Channels
-
Create a wrapper for a byte channel which does not expose other methods.
- WrappedChannel<C> - Interface in org.xnio.channels
-
A wrapped channel.
- WritableMessageChannel - Interface in org.xnio.channels
-
A channel that can send messages.
- WritableMultipointMessageChannel - Interface in org.xnio.channels
-
The writable side of a multipoint message channel.
- write(byte[]) - Method in class org.xnio.streams.ChannelOutputStream
- write(byte[], int, int) - Method in class org.xnio.streams.BufferPipeOutputStream
- write(byte[], int, int) - Method in class org.xnio.streams.ChannelOutputStream
- write(byte[], int, int) - Method in class org.xnio.streams.LimitedOutputStream
- write(byte[], int, int) - Method in class org.xnio.streams.WriterOutputStream
- write(int) - Method in class org.xnio.streams.BufferPipeOutputStream
- write(int) - Method in class org.xnio.streams.ChannelOutputStream
- write(int) - Method in class org.xnio.streams.LimitedOutputStream
- write(int) - Method in class org.xnio.streams.WriterOutputStream
- write(ByteBuffer) - Method in class java.nio.channels.FileChannel
- write(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
- write(ByteBuffer) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking write operation.
- write(ByteBuffer) - Method in class org.xnio.channels.BlockingWritableByteChannel
-
Perform a blocking write operation.
- write(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- write(ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
- write(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
- write(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- write(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableByteChannel
- write(ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
- write(ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- write(ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes a sequence of bytes to this conduit from the given buffer.
- write(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- write(ByteBuffer[]) - Method in class java.nio.channels.FileChannel
- write(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
- write(ByteBuffer[]) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, gathering write operation.
- write(ByteBuffer[]) - Method in class org.xnio.channels.BlockingWritableByteChannel
-
Perform a blocking, gathering write operation.
- write(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- write(ByteBuffer[]) - Method in class org.xnio.channels.NullStreamSinkChannel
- write(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSinkChannel
- write(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- write(ByteBuffer[], int, int) - Method in class java.nio.channels.FileChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, gathering write operation.
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingWritableByteChannel
-
Perform a blocking, gathering write operation.
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.NullStreamSinkChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSinkChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.NullStreamSinkConduit
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- write(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes a sequence of bytes to this conduit from the given buffers.
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- write(ByteBuffer, long) - Method in class java.nio.channels.FileChannel
- WRITE_ONLY - Enum constant in enum org.xnio.FileAccess
- WRITE_TIMEOUT - Static variable in class org.xnio.Options
-
Configure a write timeout for a socket, in milliseconds.
- writeBlocking(C, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write on a byte channel.
- writeBlocking(C, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write on a gathering byte channel.
- writeBlocking(C, ByteBuffer[], int, int, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write on a gathering byte channel with a timeout.
- writeBlocking(C, ByteBuffer, long, TimeUnit) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking write on a byte channel with a timeout.
- writeClosed() - Method in class org.xnio.Connection
-
Indicate that writes have been closed on this connection.
- writeClosed() - Method in class org.xnio.ssl.JsseSslStreamConnection
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
- writeFinal(ByteBuffer) - Method in interface org.xnio.channels.StreamSinkChannel
-
Writes some data to the channel, with the same semantics as
WritableByteChannel.write(java.nio.ByteBuffer)
. - writeFinal(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- writeFinal(ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes some data to the conduit, with the same semantics as
StreamSinkConduit.write(java.nio.ByteBuffer)
. - writeFinal(ByteBuffer) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.NullStreamSinkChannel
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSinkChannel
- writeFinal(ByteBuffer[]) - Method in interface org.xnio.channels.StreamSinkChannel
-
Writes some data to the channel, with the same semantics as
GatheringByteChannel.write(java.nio.ByteBuffer[])
. - writeFinal(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.NullStreamSinkChannel
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSinkChannel
- writeFinal(ByteBuffer[], int, int) - Method in interface org.xnio.channels.StreamSinkChannel
-
Writes some data to the channel, with the same semantics as
GatheringByteChannel.write(java.nio.ByteBuffer[], int, int)
. - writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.NullStreamSinkConduit
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
- writeFinal(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes some data to the conduit, with the same semantics as
StreamSinkConduit.write(java.nio.ByteBuffer[], int, int)
. - writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.SynchronizedStreamSinkConduit
- writeFinalBasic(StreamSinkChannel, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Writes out the data in the buffer to the channel.
- writeFinalBasic(StreamSinkChannel, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Writes out the data in the buffer to the channel.
- writeFinalBasic(StreamSinkConduit, ByteBuffer) - Static method in class org.xnio.conduits.Conduits
-
Writes the buffer to the conduit, and terminates writes if all the data is written
- writeFinalBasic(StreamSinkConduit, ByteBuffer[], int, int) - Static method in class org.xnio.conduits.Conduits
-
Writes the buffer to the conduit, and terminates writes if all the data is written
- WriteListenerSettable<C> - Interface in org.xnio.channels
-
An object which supports directly setting the write listener may implement this interface.
- WriteListenerSettable.Setter<C> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- writeReady() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
- writeReady() - Method in interface org.xnio.conduits.WriteReadyHandler
-
Signify that writes are ready.
- WriteReadyHandler - Interface in org.xnio.conduits
-
A conduit write-ready handler.
- WriteReadyHandler.ChannelListenerHandler<C> - Class in org.xnio.conduits
-
A write ready handler which calls channel listener(s).
- WriteReadyHandler.ReadyTask - Class in org.xnio.conduits
-
A runnable task which invokes the
WriteReadyHandler.writeReady()
method of the given handler. - writeRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.Indicate if the channel is not writable until the read handler is called.
- WriterOutputStream - Class in org.xnio.streams
-
An output stream which decodes bytes into a character writer.
- WriterOutputStream(Writer) - Constructor for class org.xnio.streams.WriterOutputStream
-
Construct a new instance.
- WriterOutputStream(Writer, String) - Constructor for class org.xnio.streams.WriterOutputStream
-
Construct a new instance.
- WriterOutputStream(Writer, Charset) - Constructor for class org.xnio.streams.WriterOutputStream
-
Construct a new instance.
- WriterOutputStream(Writer, CharsetDecoder) - Constructor for class org.xnio.streams.WriterOutputStream
-
Construct a new instance.
- WriterOutputStream(Writer, CharsetDecoder, int) - Constructor for class org.xnio.streams.WriterOutputStream
-
Construct a new instance.
- writeShutDown() - Method in class org.xnio._private.Messages_$logger
- writeShutDown() - Method in interface org.xnio._private.Messages
- writeShutDown$str() - Method in class org.xnio._private.Messages_$logger
- writeShutdownChannelListener(ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A write shutdown channel listener.
- writeSuspendingChannelListener(ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
A write-suspending channel listener.
- writeTimeout() - Method in class org.xnio._private.Messages_$logger
- writeTimeout() - Method in interface org.xnio._private.Messages
- writeTimeout$str() - Method in class org.xnio._private.Messages_$logger
- WriteTimeoutException - Exception Class in org.xnio.channels
-
Thrown when a blocking write operation times out.
- WriteTimeoutException() - Constructor for exception class org.xnio.channels.WriteTimeoutException
-
Constructs a
WriteTimeoutException
with no detail message. - WriteTimeoutException(String) - Constructor for exception class org.xnio.channels.WriteTimeoutException
-
Constructs a
WriteTimeoutException
with the specified detail message. - WriteTimeoutException(String, Throwable) - Constructor for exception class org.xnio.channels.WriteTimeoutException
-
Constructs a
WriteTimeoutException
with the specified detail message and cause. - WriteTimeoutException(Throwable) - Constructor for exception class org.xnio.channels.WriteTimeoutException
-
Constructs a
WriteTimeoutException
with the specified cause. - writeTo(OutputStream) - Method in class org.xnio.ByteString
-
Append to an output stream.
- writingChannelListener(Pooled<ByteBuffer>, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A writing channel listener.
- wrongBufferExpansion() - Method in class org.xnio._private.Messages_$logger
- wrongBufferExpansion() - Method in interface org.xnio._private.Messages
- wrongBufferExpansion$str() - Method in class org.xnio._private.Messages_$logger
X
- xnio - Variable in class org.xnio.ssl.XnioSsl
-
The corresponding XNIO instance.
- Xnio - Class in org.xnio
-
The XNIO provider class.
- Xnio(String) - Constructor for class org.xnio.Xnio
-
Construct an XNIO provider instance.
- XnioExecutor - Interface in org.xnio
-
An executor with the capability to run timed, cancellable tasks.
- XnioExecutor.Key - Interface in org.xnio
-
A task key for a timeout task.
- XnioIoFactory - Interface in org.xnio
-
An XNIO I/O factory which can be used to create channels.
- XnioIoThread - Class in org.xnio
-
An XNIO thread.
- XnioIoThread(XnioWorker, int) - Constructor for class org.xnio.XnioIoThread
-
Construct a new instance.
- XnioIoThread(XnioWorker, int, String) - Constructor for class org.xnio.XnioIoThread
-
Construct a new instance.
- XnioIoThread(XnioWorker, int, ThreadGroup, String) - Constructor for class org.xnio.XnioIoThread
-
Construct a new instance.
- XnioIoThread(XnioWorker, int, ThreadGroup, String, long) - Constructor for class org.xnio.XnioIoThread
-
Construct a new instance.
- XnioProvider - Interface in org.xnio
-
An XNIO provider, used by the service loader discovery mechanism.
- XnioProviderMXBean - Interface in org.xnio.management
-
The MXBean interface for XNIO providers.
- XnioServerMXBean - Interface in org.xnio.management
- XnioSsl - Class in org.xnio.ssl
-
An SSL provider for XNIO.
- XnioSsl(Xnio, SSLContext, OptionMap) - Constructor for class org.xnio.ssl.XnioSsl
-
Construct a new instance.
- xnioThreadRequired() - Method in class org.xnio._private.Messages_$logger
- xnioThreadRequired() - Method in interface org.xnio._private.Messages
- xnioThreadRequired$str() - Method in class org.xnio._private.Messages_$logger
- XnioWorker - Class in org.xnio
-
A worker for I/O channel notification.
- XnioWorker(XnioWorker.Builder) - Constructor for class org.xnio.XnioWorker
-
Construct a new instance.
- XnioWorker.Builder - Class in org.xnio
-
A builder which allows workers to be programmatically configured.
- XnioWorkerConfigurator - Interface in org.xnio
-
An interface which is loaded via
ServiceLoader
in order to take over the configuration of the default worker in the event that no overriding configuration is present. - XnioWorkerMXBean - Interface in org.xnio.management
Z
- zero(ByteBuffer) - Static method in class org.xnio.Buffers
-
Zero a buffer.
- zero(CharBuffer) - Static method in class org.xnio.Buffers
-
Zero a buffer.
- zeroAndFree(ByteBuffer) - Static method in class org.xnio.ByteBufferPool
-
Free a buffer as with
ByteBufferPool.free(ByteBuffer)
except the buffer is first zeroed and cleared.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
CleanerReference
.