XNIO API 3.0.4.GA
A B C D E F G H I J K L M N O P R S T U V W X Z

A

AbstractConvertingIoFuture<T,D> - Class in org.xnio
An IoFuture implementation that wraps a different type of IoFuture.
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.
accept(ChannelListener<? super T>, ChannelListener<? super BoundChannel>) - Method in interface org.xnio.ChannelDestination
Accept a connection.
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(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
Accept a message connection at a destination address.
AcceptingChannel<C extends ConnectedChannel> - Interface in org.xnio.channels
A channel which can accept inbound connections from remote endpoints.
acceptLocalDatagram(LocalSocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to accept a local (UNIX domain) datagram connection.
acceptLocalStream(LocalSocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to accept a local (UNIX domain) stream connection.
acceptStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Accept a stream connection at a destination address.
acceptTcpStream(InetSocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to accept a TCP connection.
acknowledge(Pooled<ByteBuffer>) - Method in interface org.xnio.streams.BufferPipeInputStream.InputHandler
Acknowledges the successful processing of an input buffer.
add(Option<?>) - Method in class org.xnio.Option.SetBuilder
Add an option to this set.
add(Map<?, ?>) - Method in class org.xnio.OptionMap.Builder
Add all the entries of a map.
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.
addCancelHandler(Cancellable) - Method in class org.xnio.AbstractIoFuture
Add a cancellation handler.
addCancelHandler(Cancellable) - Method in class org.xnio.FutureResult
Add a cancellation handler.
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 interface org.xnio.IoFuture
Add a notifier to be called when this operation is complete.
addRandom(ByteBuffer, Random, int) - Static method in class org.xnio.Buffers
Add count bytes of random data to the target buffer.
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) - Static method in class org.xnio.Buffers
Add a random amount of random data to the target buffer using the thread-local RNG.
allAreClear(int, int) - Static method in class org.xnio.Bits
Determine if all of the flags in the given var are clear.
allAreClear(long, long) - Static method in class org.xnio.Bits
Determine if all of the flags in the given var are clear.
allAreSet(int, int) - Static method in class org.xnio.Bits
Determine if all of the flags in the given var are set.
allAreSet(long, long) - Static method in class org.xnio.Bits
Determine if all of the flags in the given var are set.
allocate(int) - Method in interface org.xnio.BufferAllocator
Allocate a buffer of the given size.
allocate() - Method in class org.xnio.ByteBufferSlicePool
Allocate a resource from the pool.
allocate() - Method in interface org.xnio.Pool
Allocate a resource from the 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 given var are clear.
anyAreClear(long, long) - Static method in class org.xnio.Bits
Determine if any of the flags in the given var are clear.
anyAreSet(int, int) - Static method in class org.xnio.Bits
Determine if any of the flags in the given var are set.
anyAreSet(long, long) - Static method in class org.xnio.Bits
Determine if any of the flags in the given var are set.
assertWritable(Buffer[], int, int) - Static method in class org.xnio.Buffers
Assert the writability of the given buffers.
assertWritable(Buffer...) - 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.
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(long, TimeUnit) - Method in class org.xnio.AbstractConvertingIoFuture
 
await() - Method in class org.xnio.AbstractIoFuture
Wait for the operation to complete.
await(long, TimeUnit) - Method in class org.xnio.AbstractIoFuture
Wait for the operation to complete, with a timeout.
await() - Method in interface org.xnio.IoFuture
Wait for the operation to complete.
await(long, TimeUnit) - Method in interface org.xnio.IoFuture
Wait for the operation to complete, with a timeout.
await() - Method in class org.xnio.streams.Pipe
Wait for the read side to close.
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(long, TimeUnit) - Method in class org.xnio.AbstractConvertingIoFuture
 
awaitInterruptibly() - Method in class org.xnio.AbstractIoFuture
Wait for the operation to complete.
awaitInterruptibly(long, TimeUnit) - Method in class org.xnio.AbstractIoFuture
Wait for the operation to complete, with a timeout.
awaitInterruptibly() - Method in interface org.xnio.IoFuture
Wait for the operation to complete.
awaitInterruptibly(long, TimeUnit) - Method in interface org.xnio.IoFuture
Wait for the operation to complete, with a timeout.
awaitReadable() - Method in interface org.xnio.channels.SuspendableReadChannel
Block until this channel becomes readable again.
awaitReadable(long, TimeUnit) - Method in interface org.xnio.channels.SuspendableReadChannel
Block until this channel becomes readable again, or until the timeout expires.
awaitReadable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Block until this channel becomes readable again.
awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.TranslatingSuspendableChannel
Block until this channel becomes readable again, or until the timeout expires.
awaitTermination(long, TimeUnit) - Method in class org.xnio.XnioWorker
 
awaitWritable() - Method in interface org.xnio.channels.SuspendableWriteChannel
Block until this channel becomes writable again.
awaitWritable(long, TimeUnit) - Method in interface org.xnio.channels.SuspendableWriteChannel
Block until this channel becomes writable again, or until the timeout expires.
awaitWritable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Block until this channel becomes writable again.
awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.TranslatingSuspendableChannel
Block until this channel becomes writable again, or until the timeout expires.

B

BACKLOG - Static variable in class org.xnio.Options
Configure a server with the specified backlog.
bind(SocketAddress) - Method in interface org.xnio.channels.BoundServerChannel
Add a binding.
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.
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.
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.
BoundServerChannel - Interface in org.xnio.channels
A server that is bound to one or more local addresses.
BROADCAST - Static variable in class org.xnio.Options
Enable broadcast support for IP datagram sockets.
BufferAllocator<B extends Buffer> - 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.
BufferPipeInputStream - Class in org.xnio.streams
An InputStream implementation which is populated asynchronously with ByteBuffer 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 out ByteBuffers 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.
builder() - Static method in class org.xnio.OptionMap
Create a new builder.
BYTE_BUFFER_ALLOCATOR - Static variable in interface org.xnio.BufferAllocator
A simple allocator for heap-array-backed byte buffers.
ByteBufferSlicePool - Class in org.xnio
A buffer pooled allocator.
ByteBufferSlicePool(BufferAllocator<ByteBuffer>, int, int) - Constructor for class org.xnio.ByteBufferSlicePool
Construct a new instance.
ByteBufferSlicePool(int, int) - Constructor for class org.xnio.ByteBufferSlicePool
Construct a new instance, using a direct buffer allocator.
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

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.
cast(IoFuture<I>, Class<O>) - Static method in class org.xnio.IoUtils
Create an IoFuture which wraps another IoFuture, but returns a different type.
cast(Object) - Method in class org.xnio.Option
Return the given object as the type of this option.
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.
channel - Variable in class org.xnio.channels.TranslatingSuspendableChannel
The wrapped channel.
channel - Variable in class org.xnio.streams.ChannelInputStream
 
channel - Variable in class org.xnio.streams.ChannelOutputStream
 
ChannelDestination<T extends Channel> - Interface in org.xnio
A channel destination.
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 extends Channel> - Interface in org.xnio
A listener for channel events.
ChannelListener.Setter<T extends Channel> - Interface in org.xnio
A setter for a channel listener.
ChannelListener.SimpleSetter<T extends Channel> - Class in org.xnio
A simple implementation of ChannelListener.Setter.
ChannelListener.SimpleSetter() - Constructor for class org.xnio.ChannelListener.SimpleSetter
 
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.
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.
Channels - Class in org.xnio.channels
A utility class containing static methods to support channel usage.
ChannelSource<T extends Channel> - Interface in org.xnio
A channel source.
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.
clear(T) - Static method in class org.xnio.Buffers
Clear a buffer.
clear() - Method in class org.xnio.channels.SocketAddressBuffer
Clear both addresses in the buffer.
clearReadReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel is no longer definitely immediately readable.
clearReadRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel no longer requires writability for reads to proceed.
clearWriteReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel is no longer definitely immediately writable.
clearWriteRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel no longer requires writability for writes to proceed.
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 interface org.xnio.channels.SuspendableWriteChannel
Close this channel.
close() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Close this channel.
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 the close() 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(boolean, boolean) - Method in class org.xnio.channels.FramedMessageChannel
 
closeAction(boolean, boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
The action to perform when the channel is closed via the TranslatingSuspendableChannel.close() method.
closed - Variable in class org.xnio.streams.ChannelInputStream
 
closed - Variable in class org.xnio.streams.ChannelOutputStream
 
ClosedWorkerException - Exception in org.xnio
A channel open was attempted on a closed worker.
ClosedWorkerException() - Constructor for exception org.xnio.ClosedWorkerException
Constructs a ClosedWorkerException with no detail message.
ClosedWorkerException(String) - Constructor for exception org.xnio.ClosedWorkerException
Constructs a ClosedWorkerException with the specified detail message.
ClosedWorkerException(Throwable) - Constructor for exception org.xnio.ClosedWorkerException
Constructs a ClosedWorkerException with the specified cause.
ClosedWorkerException(String, Throwable) - Constructor for exception org.xnio.ClosedWorkerException
Constructs a ClosedWorkerException with the specified detail message and cause.
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.
closingChannelListener() - Static method in class org.xnio.ChannelListeners
Get a channel listener which closes the channel when notified.
closingNotifier() - Static method in class org.xnio.IoUtils
Get a notifier that closes the result.
compareTo(ByteString) - Method in class org.xnio.ByteString
Compare this ByteString to another.
Configurable - Interface in org.xnio.channels
A channel that has parameters that may be configured while the channel is open.
connectDatagram(SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Connect to a remote stream server.
connectDatagram(SocketAddress, SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Connect to a remote datagram server.
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.
connectLocalDatagram(LocalSocketAddress, LocalSocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to connect to a local (UNIX domain) datagram server.
connectLocalStream(LocalSocketAddress, LocalSocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to connect to a local (UNIX domain) server.
connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
 
connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
 
connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, 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.JsseXnioSsl
 
connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
Create an SSL connection to a remote host.
connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
Create an SSL connection to a remote host.
connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
Create an SSL connection to a remote host.
connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
Create an SSL connection to a remote host.
connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Connect to a remote stream server.
connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Connect to a remote stream server.
connectStream(SocketAddress, SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Connect to a remote stream server.
connectTcpStream(InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to connect to a TCP server.
connectUdpDatagram(InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Implementation helper method to connect to a UDP server.
contains(Option<?>) - Method in class org.xnio.OptionMap
Determine whether this option map contains the given option.
convert(D) - Method in class org.xnio.AbstractConvertingIoFuture
 
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 into destination.
copy(ByteBuffer[], int, int, ByteBuffer) - Static method in class org.xnio.Buffers
Copy as many bytes as possible from sources into destinations in a "scatter" fashion.
copy(ByteBuffer, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
Copy as many bytes as possible from sources into destination in a "gather" fashion.
copy(ByteBuffer[], int, int, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
Copy as many bytes as possible from sources into destinations by a combined "scatter"/"gather" operation.
copy(int, ByteBuffer, ByteBuffer) - Static method in class org.xnio.Buffers
Copy at most count bytes from source into destination.
copy(int, ByteBuffer[], int, int, ByteBuffer) - Static method in class org.xnio.Buffers
Copy at most count bytes from sources into destinations in a "scatter" fashion.
copy(int, ByteBuffer, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
Copy at most count bytes from sources into destination in a "gather" fashion.
copy(long, ByteBuffer[], int, int, ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
Copy at most count bytes from sources into destinations by a combined "scatter"/"gather" operation.
copyOf(byte[], int, int) - Static method in class org.xnio.ByteString
Create a byte string from the given array segment.
copyStream(InputStream, OutputStream, boolean, int) - 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) - Static method in class org.xnio.streams.Streams
Copy from one stream to another.
CORK - Static variable in class org.xnio.Options
Specify that output should be buffered.
create() - Method in class org.xnio.Option.SetBuilder
Create the immutable option set instance.
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.
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.
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.
createLocalStreamServer(LocalSocketAddress, ChannelListener<? super AcceptingChannel<ConnectedStreamChannel>>, 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
Open a unidirectional stream pipe.
createPipe(ChannelListener<? super StreamChannel>, ChannelListener<? super StreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
Open a bidirectional stream pipe.
createPropertyMap(OptionMap, boolean) - Static method in class org.xnio.sasl.SaslUtils
Create a SASL property map from an XNIO option map.
createSSLContext(OptionMap) - Static method in class org.xnio.ssl.JsseSslUtils
Create a new SSL context, configured from an option map.
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.
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
Create a bound TCP SSL server.
createStreamServer(SocketAddress, ChannelListener<? super AcceptingChannel<ConnectedStreamChannel>>, OptionMap) - Method in class org.xnio.XnioWorker
Create a stream server, for TCP or UNIX domain servers.
createTcpServer(InetSocketAddress, ChannelListener<? super AcceptingChannel<ConnectedStreamChannel>>, 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(OptionMap) - Method in class org.xnio.Xnio
Construct a new XNIO worker.
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.

D

delegate - Variable in class org.xnio.AbstractConvertingIoFuture
The delegate future result.
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
Discard this resource.
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 variable in class org.xnio.OptionMap
The empty option map.
empty() - Static method in class org.xnio.Sequence
Return an empty sequence.
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.
equals(Object) - Method in class org.xnio.ByteString
Determine if this ByteString equals another ByteString.
equals(ByteString) - 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(OptionMap) - 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(Property) - 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(Sequence<?>) - Method in class org.xnio.Sequence
Determine whether this sequence is equal to another.
evaluateChallenge(SaslClient, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
Evaluate a sasl challenge.
evaluateResponse(SaslServer, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
Evaluate a sasl response.
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.
executorChannelListener(ChannelListener<T>, Executor) - Static method in class org.xnio.ChannelListeners
Get a channel listener which executes a delegate channel listener via an executor.

F

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.
FILE_ACCESS - Static variable in class org.xnio.Options
The file access mode to use when opening a file.
FileAccess - Enum in org.xnio
 
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(ShortBuffer, 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.
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.
flip(T) - Static method in class org.xnio.Buffers
Flip a buffer.
flush() - Method in class org.xnio.channels.BlockingByteChannel
flush() - Method in class org.xnio.channels.BlockingWritableByteChannel
flush() - Method in interface org.xnio.channels.SuspendableWriteChannel
Flush any waiting partial send or write.
flush() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Perform channel flush.
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
 
flushAction(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
The action to perform when the channel is flushed.
flushBlocking(SuspendableWriteChannel) - Static method in class org.xnio.channels.Channels
Simple utility method to execute a blocking flush on a writable channel.
FramedMessageChannel - Class in org.xnio.channels
A connected message channel providing a SASL-style framing layer over a stream channel where each message is prepended by a four-byte length field.
FramedMessageChannel(ConnectedStreamChannel, ByteBuffer, ByteBuffer) - Constructor for class org.xnio.channels.FramedMessageChannel
Construct a new instance.
FramedMessageChannel(ConnectedStreamChannel, Pooled<ByteBuffer>, Pooled<ByteBuffer>) - Constructor for class org.xnio.channels.FramedMessageChannel
Construct a new instance.
free() - Method in interface org.xnio.Pooled
Free this resource for immediate re-use.
fromString(String, ClassLoader) - Static method in class org.xnio.Option
Get an option from a string name, using the given classloader.
fromString(String) - Static method in enum org.xnio.sasl.SaslQop
Get the SASL QOP level for the given string.
FutureResult<T> - Class in org.xnio
A result with a corresponding IoFuture instance.
FutureResult(Executor) - Constructor for class org.xnio.FutureResult
Construct a new instance.
FutureResult() - 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.ChannelListener.SimpleSetter
Get the channel listener set on this setter.
get() - Method in interface org.xnio.IoFuture
Get the result of the operation.
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.
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(int) - Method in class org.xnio.Sequence
Get the value at a certain index.
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.
getBuffer(boolean) - Method in interface org.xnio.streams.BufferPipeOutputStream.BufferWriter
Get a new buffer to be filled.
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.
getBytes() - Method in class org.xnio.ByteString
Get a copy of the bytes of this ByteString.
getBytes(byte[]) - Method in class org.xnio.ByteString
Copy the bytes of this ByteString into the destination array.
getBytes(byte[], int) - Method in class org.xnio.ByteString
Copy the bytes of this ByteString into the destination array.
getBytes(byte[], int, int) - Method in class org.xnio.ByteString
Copy the bytes of this ByteString into the destination array.
getChannel() - Method in class org.xnio.channels.FramedMessageChannel
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.TranslatingSuspendableChannel
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.
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.
getChannels() - Method in interface org.xnio.channels.BoundServerChannel
Get the channels representing the individual bound servers.
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 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.BoundServerChannel
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 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 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 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
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.
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.
getException() - Method in class org.xnio.AbstractConvertingIoFuture
 
getException() - Method in class org.xnio.AbstractIoFuture
Get the failure reason.
getException() - Method in interface org.xnio.IoFuture
Get the failure reason.
getFuture(IoFuture<T>) - Static method in class org.xnio.IoUtils
Get a java.util.concurrent-style Future instance wrapper for an IoFuture instance.
getGroup() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
Return the multicast group for which this key was created.
getHandshakeSetter() - Method in interface org.xnio.channels.SslChannel
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.
getInstance(ClassLoader) - Static method in class org.xnio.Xnio
Get an XNIO provider instance.
getInstance() - Static method in class org.xnio.Xnio
Get an XNIO provider instance from XNIO's class loader.
getInstance(String, ClassLoader) - Static method in class org.xnio.Xnio
Get a specific XNIO provider instance.
getInstance(String) - Static method in class org.xnio.Xnio
Get a specific XNIO provider instance from XNIO's class loader.
getInstance() - Method in interface org.xnio.XnioProvider
Get the XNIO instance for this provider.
getInterruptibly() - Method in class org.xnio.AbstractConvertingIoFuture
 
getInterruptibly() - Method in class org.xnio.AbstractIoFuture
Get the result of the operation.
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.
getKey() - Method in class org.xnio.Property
Get the key of this key/value Property.
getLocalAddress() - Method in interface org.xnio.channels.BoundChannel
Get the local address that this channel is bound to.
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() - Method in class org.xnio.channels.FramedMessageChannel
Get the local address that this channel is bound to.
getLocalAddress(Class<A>) - Method in class org.xnio.channels.FramedMessageChannel
Get the local address of a given type, or null if the address is not of that type.
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.
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.
getName() - Method in class org.xnio.LocalSocketAddress
Get the name (filesystem path) of this local socket address.
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.
getNotifierExecutor() - Method in class org.xnio.AbstractIoFuture
Get the executor used to run asynchronous notifiers.
getOption(Configurable, Option<T>, T) - Static method in class org.xnio.channels.Channels
Get an option value from a configurable target.
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(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.TranslatingSuspendableChannel
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 interface org.xnio.channels.ConnectedChannel
Get the peer address of this channel.
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() - Method in class org.xnio.channels.FramedMessageChannel
Get the peer address of this channel.
getPeerAddress(Class<A>) - Method in class org.xnio.channels.FramedMessageChannel
Get the peer address of a given type, or null if the address is not of that type.
getProperty(String) - Method in class org.xnio.Xnio
Get an XNIO property.
getProperty(String, String) - Method in class org.xnio.Xnio
Get an XNIO property.
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 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 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 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
Get the setter which can be used to change the read listener for this channel.
getReadThread() - Method in interface org.xnio.channels.SuspendableReadChannel
Get the read thread for this channel.
getReadThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
 
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.
getResource() - Method in interface org.xnio.Pooled
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.
getSaslClientFactories(ClassLoader, boolean) - Static method in class org.xnio.sasl.SaslUtils
Returns an iterator of all of the registered SaslClientFactorys where the order is based on the order of the Provider registration and/or class path order.
getSaslClientFactories() - Static method in class org.xnio.sasl.SaslUtils
Returns an iterator of all of the registered SaslClientFactorys 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 SaslServerFactorys 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 SaslServerFactorys where the order is based on the order of the Provider registration and/or class path order.
getSetter(C, AtomicReferenceFieldUpdater<C, ChannelListener>) - Static method in class org.xnio.ChannelListeners
Get a setter based on an atomic reference field updater.
getSetter(AtomicReference<ChannelListener<? super T>>) - Static method in class org.xnio.ChannelListeners
Get a setter based on an atomic reference.
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.
getSslContext() - Method in class org.xnio.ssl.JsseXnioSsl
Get the JSSE SSL context for this provider instance.
getSslProvider(OptionMap) - Method in class org.xnio.Xnio
Get an SSL provider for this XNIO provider.
getSslProvider(KeyManager[], TrustManager[], OptionMap) - Method in class org.xnio.Xnio
Get an SSL provider for this XNIO provider.
getSslSession() - Method in interface org.xnio.channels.SslChannel
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 interface org.xnio.IoFuture
Get the current status.
getString() - Method in enum org.xnio.sasl.SaslQop
Get the string representation of this SASL QOP value.
getTerminationTask() - Method in class org.xnio.XnioWorker
Get the user task to run once termination is complete.
getThreadLocalRandom() - Static method in class org.xnio.IoUtils
Get a thread-local RNG.
getValue() - Method in class org.xnio.Property
Get the value of this key/value Property.
getVersionString() - Static method in class org.xnio.Version
Get the version string.
getWorker() - Method in interface org.xnio.channels.CloseableChannel
Get the worker for this channel.
getWorker() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Get the worker for this channel.
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 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 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
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.
getWriteThread() - Method in interface org.xnio.channels.SuspendableWriteChannel
Get the write thread for this channel.
getWriteThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
 
getWriteTimeout(TimeUnit) - Method in class org.xnio.streams.ChannelOutputStream
Get the write timeout.
getXnio() - Method in class org.xnio.XnioWorker
Get the XNIO provider which produced this worker.

H

handleCancelled(A) - Method in class org.xnio.IoFuture.HandlingNotifier
Handle cancellation.
handleClosed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Called when the underlying channel is closed.
handleDone(T, A) - Method in class org.xnio.IoFuture.HandlingNotifier
Handle completion.
handleEvent(T) - Method in interface org.xnio.ChannelListener
Handle the event on this channel.
handleFailed(IOException, A) - Method in class org.xnio.IoFuture.HandlingNotifier
Handle failure.
handleReadable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Called when the underlying channel is readable.
handleWritable() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Called when the underlying channel is writable.
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.
hasRemaining(Buffer[], int, int) - Static method in class org.xnio.Buffers
Determine whether any of the buffers has remaining data.
hasRemaining(Buffer[]) - Static method in class org.xnio.Buffers
Determine whether any of the buffers has remaining data.

I

IMMEDIATE - Static variable in interface org.xnio.XnioExecutor.Key
An immediate key.
intBitMask(int, int) - Static method in class org.xnio.Bits
Get an integer bit mask consisting of 1 bits in the given range.
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.
invokeChannelListener(T, ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
Invoke a channel listener on a given channel, 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.
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.HandlingNotifier() - Constructor for class org.xnio.IoFuture.HandlingNotifier
 
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.
isBlockingAllowed() - Static method in class org.xnio.Xnio
Determine whether blocking I/O is allowed from the current thread.
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.
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 interface org.xnio.channels.MulticastMessageChannel.Key
Determine if this membership is active.
isOpen() - Method in class org.xnio.channels.TranslatingSuspendableChannel
isReadResumed() - Method in interface org.xnio.channels.SuspendableReadChannel
Determine whether reads are resumed.
isReadResumed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
 
isReadShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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
 
isTerminated() - Method in class org.xnio.XnioWorker
 
isWriteComplete() - Method in class org.xnio.channels.TranslatingSuspendableChannel
 
isWriteResumed() - Method in interface org.xnio.channels.SuspendableWriteChannel
Determine whether writes are resumed.
isWriteResumed() - Method in class org.xnio.channels.TranslatingSuspendableChannel
 
isWriteShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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

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.
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 a periodic heartbeat of some sort.

L

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.
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.
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.

M

main(String[]) - Static method in class org.xnio.Version
Print out the current XNIO version on System.out.
mark(T) - Static method in class org.xnio.Buffers
Set the buffer mark.
mark(int) - Method in class org.xnio.streams.LimitedInputStream
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.
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.
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

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.
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.
nullSetter() - Static method in class org.xnio.ChannelListeners
Get a channel listener setter which does nothing.

O

of(byte...) - Static method in class org.xnio.ByteString
Create a byte string of the given literal bytes.
of(String, String) - Static method in class org.xnio.Property
Create a new property for the specified key and value.
of(T...) - Static method in class org.xnio.Sequence
Return a sequence of the given members.
of(Collection<T>) - Static method in class org.xnio.Sequence
Return a sequence of the given members.
open(ChannelListener<? super T>) - Method in interface org.xnio.ChannelSource
Open a channel.
openFile(File, OptionMap) - 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.
openFile(File, FileAccess) - 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.
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.
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.
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.
Options - Class in org.xnio
Common channel options.
org.xnio - package org.xnio
The main API package for XNIO.
org.xnio.channels - package org.xnio.channels
 
org.xnio.sasl - package org.xnio.sasl
 
org.xnio.ssl - package org.xnio.ssl
 
org.xnio.streams - package org.xnio.streams
 

P

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, ClassLoader) - Method in class org.xnio.OptionMap.Builder
Add all options from a properties file.
parseAll(Properties, String) - 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.
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
A generic pooled resource manager.
PoolDepletedException - Exception in org.xnio
Exception thrown when a pool has no more available resources to allocate.
PoolDepletedException() - Constructor for exception org.xnio.PoolDepletedException
Constructs a PoolDepletedException with no detail message.
PoolDepletedException(String) - Constructor for exception org.xnio.PoolDepletedException
Constructs a PoolDepletedException with the specified detail message.
PoolDepletedException(Throwable) - Constructor for exception org.xnio.PoolDepletedException
Constructs a PoolDepletedException with the specified cause.
PoolDepletedException(String, Throwable) - Constructor for exception org.xnio.PoolDepletedException
Constructs a PoolDepletedException with the specified detail message and cause.
Pooled<T> - Interface in org.xnio
A resource which is pooled.
pooledWrapper(B) - Static method in class org.xnio.Buffers
Create a pooled wrapper around a buffer.
position(T, int) - Static method in class org.xnio.Buffers
Set the buffer position.
Property - Class in org.xnio
An immutable property represented by a key and value.
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.
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

read(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking, scattering read operation.
read(ByteBuffer[]) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking, scattering read operation.
read(ByteBuffer) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking read operation.
read(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingReadableByteChannel
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.BlockingReadableByteChannel
Perform a blocking read operation.
read() - Method in class org.xnio.streams.BufferedChannelInputStream
Read a byte, blocking if necessary.
read(byte[], int, int) - Method in class org.xnio.streams.BufferedChannelInputStream
Read bytes into an array.
read() - Method in class org.xnio.streams.BufferPipeInputStream
read(byte[], int, int) - Method in class org.xnio.streams.BufferPipeInputStream
read() - Method in class org.xnio.streams.ChannelInputStream
read(byte[]) - Method in class org.xnio.streams.ChannelInputStream
read(byte[], int, int) - Method in class org.xnio.streams.ChannelInputStream
read() - Method in class org.xnio.streams.LimitedInputStream
read(byte[], int, int) - Method in class org.xnio.streams.LimitedInputStream
read() - Method in class org.xnio.streams.ReaderInputStream
read(byte[], int, int) - Method in class org.xnio.streams.ReaderInputStream
READ_TIMEOUT - Static variable in class org.xnio.Options
Configure a read timeout for a socket, in milliseconds.
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.
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, 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.
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.
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.
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-terminated modified 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-terminated modified UTF-8 string from a byte buffer, appending the results to the given string builder.
readRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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.
ReadTimeoutException - Exception in org.xnio.channels
Thrown when a blocking read operation times out.
ReadTimeoutException() - Constructor for exception org.xnio.channels.ReadTimeoutException
Constructs a ReadTimeoutException with no detail message.
ReadTimeoutException(String) - Constructor for exception org.xnio.channels.ReadTimeoutException
Constructs a ReadTimeoutException with the specified detail message.
ReadTimeoutException(Throwable) - Constructor for exception org.xnio.channels.ReadTimeoutException
Constructs a ReadTimeoutException with the specified cause.
ReadTimeoutException(String, Throwable) - Constructor for exception org.xnio.channels.ReadTimeoutException
Constructs a ReadTimeoutException with the specified detail message and cause.
receive(ByteBuffer) - Method in class org.xnio.channels.FramedMessageChannel
Receive a message.
receive(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
Receive a message.
receive(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
Receive a message.
receive(ByteBuffer) - Method in interface org.xnio.channels.ReadableMessageChannel
Receive a message.
receive(ByteBuffer[]) - Method in interface org.xnio.channels.ReadableMessageChannel
Receive a message.
receive(ByteBuffer[], int, int) - Method in interface org.xnio.channels.ReadableMessageChannel
Receive a message.
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, 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[], 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.
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.
remaining(Buffer[], int, int) - Static method in class org.xnio.Buffers
Get the total remaining size of all the given buffers.
remaining(Buffer[]) - 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.
removeReadRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that one external read task was completed.
removeWriteRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that one external write task was completed.
reset(T) - Static method in class org.xnio.Buffers
Reset the buffer.
reset() - Method in class org.xnio.streams.LimitedInputStream
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 interface org.xnio.channels.SuspendableReadChannel
Resume reads on this channel.
resumeReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Resume reads on this channel.
resumeWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
Resume writes on this channel.
resumeWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Resume writes on this channel.
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
 
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.

S

safeClose(Closeable) - 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(DatagramSocket) - 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(ServerSocket) - 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(Handler) - 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.
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
 
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.FramedMessageChannel
Send a complete message.
send(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
Send a complete message.
send(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
Send a complete message.
send(ByteBuffer) - Method in interface org.xnio.channels.WritableMessageChannel
Send a complete message.
send(ByteBuffer[]) - Method in interface org.xnio.channels.WritableMessageChannel
Send a complete message.
send(ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMessageChannel
Send a complete message.
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, 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.
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.
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 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<T>, T) - Method in class org.xnio.OptionMap.Builder
Set a key-value pair.
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<Boolean>, boolean) - Method in class org.xnio.OptionMap.Builder
Set a boolean value for a Boolean key.
setAcceptListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
Set the accept listener for a channel (type-safe).
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
Set both the channel read and write shut down flags.
setCloseListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
Set the close listener for a channel (type-safe).
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
 
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.TranslatingSuspendableChannel
Set an option for this channel.
setOption(Option<T>, T) - Method in class org.xnio.XnioWorker
 
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
Indicate that the channel is definitely immediately readable, regardless of the underlying channel state.
setReadRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel will not be readable until the write handler is called.
setReadShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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<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<Boolean>>, boolean...) - Method in class org.xnio.OptionMap.Builder
Set boolean values for an Boolean 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.
setSourceAddress(SocketAddress) - Method in class org.xnio.channels.SocketAddressBuffer
Set the source address.
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
Indicate that the channel is definitely immediately writable, regardless of the underlying channel state.
setWriteRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that the channel will not be writable until the read handler is called.
setWriteShutDown() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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
 
shutdownNow() - Method in class org.xnio.XnioWorker
 
shutdownReads() - Method in interface org.xnio.channels.SuspendableReadChannel
Places this readable channel at "end of stream".
shutdownReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Perform the read shutdown action if it hasn't been performed already.
shutdownReadsAction(boolean) - Method in class org.xnio.channels.FramedMessageChannel
 
shutdownReadsAction(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
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 interface org.xnio.channels.SuspendableWriteChannel
Indicate that writing is complete for this channel.
shutdownWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Base implementation method which simply delegates the shutdown request to the delegate channel.
shutdownWritesAction() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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.
shutdownWritesComplete(boolean) - Method in class org.xnio.channels.FramedMessageChannel
 
shutdownWritesComplete(boolean) - Method in class org.xnio.channels.TranslatingSuspendableChannel
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 extends CloseableChannel> - Interface in org.xnio.channels
A channel which can accept connections.
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(T, int) - Static method in class org.xnio.Buffers
Advance a buffer's position relative to its current position.
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.LimitedInputStream
skip(long) - Method in class org.xnio.streams.ReaderInputStream
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(ShortBuffer, 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.
sliceAllocator(ByteBuffer) - Static method in class org.xnio.Buffers
A buffer allocator which allocates slices off of the given buffer.
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.
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_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.
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 interface org.xnio.channels.SslChannel
Start or restart the SSL/TLS handshake.
StreamChannel - Interface in org.xnio.channels
A stream channel.
Streams - Class in org.xnio.streams
Stream utility class.
StreamSinkChannel - Interface in org.xnio.channels
A stream sink channel.
StreamSourceChannel - Interface in org.xnio.channels
A stream source channel.
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 interface org.xnio.channels.Configurable
Determine whether an option is supported on this channel.
supportsOption(Option<?>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
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 interface org.xnio.channels.SuspendableReadChannel
Suspend further read notifications on this channel.
suspendReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Suspend further read notifications on this channel.
suspendWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
Suspend further write notifications on this channel.
suspendWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Suspend further write notifications on this channel.

T

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, int) - Static method in class org.xnio.Buffers
Take a certain number of chars 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.
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, int) - Static method in class org.xnio.Buffers
Take a certain number of longs from the buffer and return them in an array.
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(CharBuffer) - Static method in class org.xnio.Buffers
Take all of the remaining chars 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(IntBuffer) - Static method in class org.xnio.Buffers
Take all of the remaining 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.
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.
thisTyped() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Get this channel, cast to the implemented channel type.
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.
timeout - Variable in class org.xnio.streams.ChannelInputStream
 
timeout - Variable in class org.xnio.streams.ChannelOutputStream
 
toArray() - Method in class org.xnio.Sequence
Get a copy of the values array.
toString(String) - Method in class org.xnio.ByteString
Convert this byte string to a standard string.
toString() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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 enum org.xnio.sasl.SaslQop
Get the human-readable string representation of this SASL QOP 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.
transfer(ReadableByteChannel, long, ByteBuffer, WritableByteChannel) - Static method in class org.xnio.IoUtils
Platform-independent channel-to-channel transfer method.
transferBlocking(StreamSinkChannel, FileChannel, long, long) - Static method in class org.xnio.channels.Channels
Transfer bytes between two channels efficiently, blocking if necessary.
transferBlocking(FileChannel, StreamSourceChannel, long, long) - Static method in class org.xnio.channels.Channels
Transfer bytes between two channels efficiently, blocking if necessary.
transferFrom(FileChannel, long, long) - Method in interface org.xnio.channels.StreamSinkChannel
Transfer bytes into this channel from the given file.
transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in interface org.xnio.channels.StreamSinkChannel
Transfers bytes from the given channel source.
transferTo(long, long, FileChannel) - Method in interface org.xnio.channels.StreamSourceChannel
Transfers bytes into the given file from this channel.
transferTo(long, ByteBuffer, StreamSinkChannel) - Method in interface org.xnio.channels.StreamSourceChannel
Transfers bytes into the given channel target.
translate(T) - Method in class org.xnio.TranslatingResult
 
TranslatingResult<T,O> - Class in org.xnio
Abstract base class for Results which translate from one type to another.
TranslatingResult(Result<O>) - Constructor for class org.xnio.TranslatingResult
 
TranslatingSuspendableChannel<C extends SuspendableChannel,W extends SuspendableChannel> - Class in org.xnio.channels
An abstract wrapped channel.
TranslatingSuspendableChannel(W) - Constructor for class org.xnio.channels.TranslatingSuspendableChannel
Construct a new instance.
tryAddReadRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that read requires an external task to complete.
tryAddWriteRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
Indicate that write requires an external task to complete.
trySkip(Buffer, int) - Static method in class org.xnio.Buffers
Attempt to advance a buffer's position relative to its current position.
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.
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.
unget(T, int) - Static method in class org.xnio.Buffers
Rewind a buffer's position relative to its current position.
unsigned(byte) - 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.
unsigned(int) - Static method in class org.xnio.Bits
Convert a signed value to unsigned.
UnsupportedOptionException - Exception in org.xnio.channels
An exception that is thrown when an invalid option is specified for a Configurable.
UnsupportedOptionException() - Constructor for exception org.xnio.channels.UnsupportedOptionException
Construct a UnsupportedOptionException instance.
UnsupportedOptionException(String) - Constructor for exception org.xnio.channels.UnsupportedOptionException
Construct a UnsupportedOptionException instance with the given message.
UnsupportedOptionException(String, Throwable) - Constructor for exception org.xnio.channels.UnsupportedOptionException
Construct a UnsupportedOptionException instance with the given message and cause.
UnsupportedOptionException(Throwable) - Constructor for exception org.xnio.channels.UnsupportedOptionException
Construct a UnsupportedOptionException instance with the given cause.
unwrap(Class<T>, Channel) - Static method in class org.xnio.channels.Channels
Unwrap a nested channel type.
unwrap(SaslClient, ByteBuffer, 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.
unwrap(byte[], int, int) - Method in class org.xnio.sasl.SaslWrapper
Unwrap a message.
unwrap(byte[]) - Method in class org.xnio.sasl.SaslWrapper
Unwrap a message.
unwrap(ByteBuffer, ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
Unwrap a message.
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.FileAccess
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.FileAccess
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
The current XNIO version.

W

wakeupAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
SuspendableAcceptChannel.resumeAccepts() Resume accepts} on this channel, and force the accept listener to be triggered even if the channel isn't actually ready.
wakeupReads() - Method in interface org.xnio.channels.SuspendableReadChannel
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.channels.TranslatingSuspendableChannel
Resume reads on this channel, and force the read listener to be triggered even if the channel isn't actually readable.
wakeupWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
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.channels.TranslatingSuspendableChannel
Resume writes on this channel, and force the write listener to be triggered even if the channel isn't actually writable.
WORKER_ACCEPT_THREADS - Static variable in class org.xnio.Options
Specify the number of accept threads a single socket server should have.
WORKER_ESTABLISH_WRITING - Static variable in class org.xnio.Options
Specify whether a server, acceptor, or connector should be attached to write threads.
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 read threads to create for the worker.
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 write threads to create for the worker.
wrap(SaslClient, ByteBuffer, 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.
wrap(byte[], int, int) - Method in class org.xnio.sasl.SaslWrapper
Wrap a message.
wrap(byte[]) - Method in class org.xnio.sasl.SaslWrapper
Wrap a message.
wrap(ByteBuffer, ByteBuffer) - Method in class org.xnio.sasl.SaslWrapper
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 extends Channel> - 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(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking, gathering write operation.
write(ByteBuffer[]) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking, gathering write operation.
write(ByteBuffer) - Method in class org.xnio.channels.BlockingByteChannel
Perform a blocking write operation.
write(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingWritableByteChannel
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.BlockingWritableByteChannel
Perform a blocking write operation.
write(int) - Method in class org.xnio.streams.BufferPipeOutputStream
write(byte[], int, int) - Method in class org.xnio.streams.BufferPipeOutputStream
write(int) - Method in class org.xnio.streams.ChannelOutputStream
write(byte[]) - Method in class org.xnio.streams.ChannelOutputStream
write(byte[], int, int) - Method in class org.xnio.streams.ChannelOutputStream
write(int) - Method in class org.xnio.streams.LimitedOutputStream
write(byte[], int, int) - Method in class org.xnio.streams.LimitedOutputStream
write(int) - Method in class org.xnio.streams.WriterOutputStream
write(byte[], int, int) - Method in class org.xnio.streams.WriterOutputStream
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, 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.
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.
writeRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
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, 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.
WriterOutputStream(Writer, Charset) - 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.
WriteTimeoutException - Exception in org.xnio.channels
Thrown when a blocking write operation times out.
WriteTimeoutException() - Constructor for exception org.xnio.channels.WriteTimeoutException
Constructs a WriteTimeoutException with no detail message.
WriteTimeoutException(String) - Constructor for exception org.xnio.channels.WriteTimeoutException
Constructs a WriteTimeoutException with the specified detail message.
WriteTimeoutException(Throwable) - Constructor for exception org.xnio.channels.WriteTimeoutException
Constructs a WriteTimeoutException with the specified cause.
WriteTimeoutException(String, Throwable) - Constructor for exception org.xnio.channels.WriteTimeoutException
Constructs a WriteTimeoutException with the specified detail message and cause.

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.
XnioProvider - Interface in org.xnio
An XNIO provider, used by the service loader discovery mechanism.
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.
XnioWorker - Class in org.xnio
A worker for I/O channel notification.
XnioWorker(Xnio, ThreadGroup, OptionMap, Runnable) - Constructor for class org.xnio.XnioWorker
Construct a new instance.

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.

A B C D E F G H I J K L M N O P R S T U V W X Z
XNIO API 3.0.4.GA

Copyright © 2010 JBoss, a division of Red Hat, Inc.