- AbstractConduit<D extends Conduit> - Class in org.xnio.conduits
-
An abstract base class for filtering conduits.
- AbstractConduit(D) - Constructor for class org.xnio.conduits.AbstractConduit
-
Construct a new instance.
- AbstractConvertingIoFuture<T,D> - Class in org.xnio
-
An IoFuture
implementation that wraps a different type 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.
- AbstractMessageSinkConduit<D extends MessageSinkConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering message sink conduits.
- AbstractMessageSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractMessageSinkConduit
-
Construct a new instance.
- AbstractMessageSourceConduit<D extends MessageSourceConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering message source conduits.
- AbstractMessageSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractMessageSourceConduit
-
Construct a new instance.
- AbstractSinkConduit<D extends SinkConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering output conduits.
- AbstractSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractSinkConduit
-
Construct a new instance.
- AbstractSourceConduit<D extends SourceConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering source conduits.
- AbstractSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractSourceConduit
-
Construct a new instance.
- AbstractStreamSinkConduit<D extends StreamSinkConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering stream sink conduits.
- AbstractStreamSinkConduit(D) - Constructor for class org.xnio.conduits.AbstractStreamSinkConduit
-
Construct a new instance.
- AbstractStreamSourceConduit<D extends StreamSourceConduit> - Class in org.xnio.conduits
-
An abstract base class for filtering stream source conduits.
- AbstractStreamSourceConduit(D) - Constructor for class org.xnio.conduits.AbstractStreamSourceConduit
-
Construct a new instance.
- 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
-
Deprecated.
- acceptFailed(AcceptingChannel<? extends ConnectedChannel>, IOException) - Method in interface org.xnio._private.Messages
-
- AcceptingChannel<C extends ConnectedChannel> - Interface in org.xnio.channels
-
A channel which can accept inbound connections from remote endpoints.
- AcceptListenerSettable<C extends Channel> - Interface in org.xnio.channels
-
An object which supports directly setting the accept listener may implement this interface.
- AcceptListenerSettable.Setter<C extends Channel> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- AcceptListenerSettable.Setter(AcceptListenerSettable<C>) - Constructor for class org.xnio.channels.AcceptListenerSettable.Setter
-
Construct a new instance.
- acceptLocalMessageConnection(LocalSocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a local (UNIX domain) datagram connection.
- acceptLocalStreamConnection(LocalSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a local (UNIX domain) stream connection.
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Accept a message connection at a destination address.
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
- acceptMessageConnection(SocketAddress, ChannelListener<? super MessageConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
- acceptStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in interface org.xnio.XnioIoFactory
-
Accept a stream connection at a destination address.
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
- acceptStreamConnection(SocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
- acceptTcpStreamConnection(InetSocketAddress, ChannelListener<? super StreamConnection>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioIoThread
-
Implementation helper method to accept a TCP connection.
- 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 class org.xnio.FinishedIoFuture
-
- addNotifier(IoFuture.Notifier<? super T, A>, A) - Method in interface org.xnio.IoFuture
-
Add a notifier to be called when this operation is complete.
- addRandom(ByteBuffer, 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.
- appBufferTooSmall() - Method in interface org.xnio._private.Messages
-
- AssembledChannel - Class in org.xnio.channels
-
A closeable view over a read and write side of a suspendable channel.
- AssembledChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledChannel
-
Construct a new instance.
- AssembledConnectedChannel - Class in org.xnio.channels
-
A closeable, connected view over a read and write side of a suspendable channel, at least one of which is connected.
- AssembledConnectedChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledConnectedChannel
-
Construct a new instance.
- AssembledConnectedMessageChannel - Class in org.xnio.channels
-
A connected bidirectional message channel assembled from a readable and writable message channel.
- AssembledConnectedMessageChannel(ConnectedChannel, ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledConnectedMessageChannel
-
Construct a new instance.
- AssembledConnectedMessageChannel(ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledConnectedMessageChannel
-
Construct a new instance.
- AssembledConnectedSslStreamChannel - Class in org.xnio.channels
-
A connected SSL stream channel assembled from a stream source and stream sink.
- AssembledConnectedSslStreamChannel(SslChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedSslStreamChannel
-
Construct a new instance.
- AssembledConnectedSslStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedSslStreamChannel
-
Construct a new instance.
- AssembledConnectedStreamChannel - Class in org.xnio.channels
-
A connected stream channel assembled from a stream source and stream sink.
- AssembledConnectedStreamChannel(ConnectedChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedStreamChannel
-
Construct a new instance.
- AssembledConnectedStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledConnectedStreamChannel
-
Construct a new instance.
- AssembledMessageChannel - Class in org.xnio.channels
-
A bidirectional message channel assembled from a readable and writable message channel.
- AssembledMessageChannel(CloseableChannel, ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledMessageChannel
-
Construct a new instance.
- AssembledMessageChannel(ReadableMessageChannel, WritableMessageChannel) - Constructor for class org.xnio.channels.AssembledMessageChannel
-
Construct a new instance.
- AssembledSslChannel - Class in org.xnio.channels
-
An assembled SSL channel.
- AssembledSslChannel(SuspendableReadChannel, SuspendableWriteChannel) - Constructor for class org.xnio.channels.AssembledSslChannel
-
Construct a new instance.
- AssembledStreamChannel - Class in org.xnio.channels
-
A stream channel assembled from a stream source and stream sink.
- AssembledStreamChannel(CloseableChannel, StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledStreamChannel
-
Construct a new instance.
- AssembledStreamChannel(StreamSourceChannel, StreamSinkChannel) - Constructor for class org.xnio.channels.AssembledStreamChannel
-
Construct a new instance.
- assertWritable(Buffer[], 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.
- AutomaticReference<T> - Class in org.xnio
-
An automatic reference is a phantom reference which is automatically freed by a background thread when it is
enqueued.
- AutomaticReference(T, Object) - Constructor for class org.xnio.AutomaticReference
-
Construct a new instance.
- available() - Method in class org.xnio.streams.BufferedChannelInputStream
-
Return the number of bytes available to read, or 0 if a subsequent read()
operation would block.
- available() - Method in class org.xnio.streams.BufferPipeInputStream
- available() - Method in class org.xnio.streams.LimitedInputStream
- available() - Method in class org.xnio.streams.ReaderInputStream
- await() - Method in class org.xnio.AbstractConvertingIoFuture
-
- await(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 class org.xnio.FinishedIoFuture
-
- await(long, TimeUnit) - Method in class org.xnio.FinishedIoFuture
-
- 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 class org.xnio.FinishedIoFuture
-
- awaitInterruptibly(long, TimeUnit) - Method in class org.xnio.FinishedIoFuture
-
- 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 class org.xnio.channels.AssembledMessageChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.AssembledMessageChannel
-
- awaitReadable() - Method in class org.xnio.channels.AssembledStreamChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.AssembledStreamChannel
-
- awaitReadable() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- awaitReadable() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- awaitReadable() - Method in class org.xnio.channels.PushBackStreamChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.PushBackStreamChannel
-
- awaitReadable() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- 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.
- awaitReadable() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSourceConduit
-
- awaitReadable() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- awaitReadable() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- awaitReadable() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- awaitReadable() - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- awaitReadable() - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- awaitReadable() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- awaitReadable() - Method in interface org.xnio.conduits.SourceConduit
-
Block until this channel becomes readable again.
- awaitReadable(long, TimeUnit) - Method in interface org.xnio.conduits.SourceConduit
-
Block until this conduit becomes readable again, or until the timeout expires.
- awaitReadable() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- awaitReadable(long, TimeUnit) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- awaitTermination(long, TimeUnit) - Method in class org.xnio.XnioWorker
-
Wait for termination.
- awaitTermination() - Method in class org.xnio.XnioWorker
-
Wait for termination.
- awaitWritable() - Method in class org.xnio.channels.AssembledMessageChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.AssembledMessageChannel
-
- awaitWritable() - Method in class org.xnio.channels.AssembledStreamChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.AssembledStreamChannel
-
- awaitWritable() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- awaitWritable() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- awaitWritable() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- 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.
- awaitWritable() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.AbstractSinkConduit
-
- awaitWritable() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- awaitWritable() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- awaitWritable() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- awaitWritable() - Method in interface org.xnio.conduits.SinkConduit
-
Block until this channel becomes writable again.
- awaitWritable(long, TimeUnit) - Method in interface org.xnio.conduits.SinkConduit
-
Block until this conduit becomes writable again, or until the timeout expires.
- awaitWritable() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- awaitWritable(long, TimeUnit) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- BACKLOG - Static variable in class org.xnio.Options
-
Configure a server with the specified backlog.
- badCompressionFormat() - Method in interface org.xnio._private.Messages
-
- badSockType(Class<? extends SocketAddress>) - Method in interface org.xnio._private.Messages
-
- BALANCING_CONNECTIONS - Static variable in class org.xnio.Options
-
The number of connections to create per connection-balancing token, if connection-balancing is enabled.
- BALANCING_TOKENS - Static variable in class org.xnio.Options
-
The number of balancing tokens, if connection-balancing is enabled.
- Bits - Class in org.xnio
-
General bit-affecting utility methods.
- block(InetAddress) - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Block multicast packets from the given source address.
- BlockingByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a StreamChannel
.
- BlockingByteChannel(StreamChannel) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- BlockingByteChannel(StreamChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- BlockingByteChannel(StreamChannel, long, TimeUnit, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingByteChannel
-
Construct a new instance.
- blockingNotAllowed() - Method in interface org.xnio._private.Messages
-
- BlockingReadableByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a StreamSourceChannel
.
- BlockingReadableByteChannel(StreamSourceChannel) - Constructor for class org.xnio.channels.BlockingReadableByteChannel
-
Construct a new instance.
- BlockingReadableByteChannel(StreamSourceChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingReadableByteChannel
-
Construct a new instance.
- BlockingStreamSinkConduit - Class in org.xnio.conduits
-
- BlockingStreamSinkConduit(StreamSinkConduit) - Constructor for class org.xnio.conduits.BlockingStreamSinkConduit
-
- BlockingStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which can switch into and out of blocking mode.
- BlockingStreamSourceConduit(StreamSourceConduit) - Constructor for class org.xnio.conduits.BlockingStreamSourceConduit
-
Construct a new instance.
- BlockingWritableByteChannel - Class in org.xnio.channels
-
A blocking wrapper for a StreamChannel
.
- BlockingWritableByteChannel(StreamSinkChannel) - Constructor for class org.xnio.channels.BlockingWritableByteChannel
-
Construct a new instance.
- BlockingWritableByteChannel(StreamSinkChannel, long, TimeUnit) - Constructor for class org.xnio.channels.BlockingWritableByteChannel
-
Construct a new instance.
- BoundChannel - Interface in org.xnio.channels
-
A channel that is bound to a local address.
- BoundMultipointMessageChannel - Interface in org.xnio.channels
-
A multipoint datagram channel.
- breakPipe() - Method in class org.xnio.streams.BufferPipeOutputStream
-
Break the pipe and return any filling pooled buffer.
- BROADCAST - Static variable in class org.xnio.Options
-
Enable broadcast support for IP datagram sockets.
- BrokenPipeException - Exception in org.xnio
-
An exception that signifies that a pipe, stream, or channel was closed from the read side while the write side was
still writing.
- BrokenPipeException() - Constructor for exception org.xnio.BrokenPipeException
-
Constructs a BrokenPipeException
with no detail message.
- BrokenPipeException(String) - Constructor for exception org.xnio.BrokenPipeException
-
Constructs a BrokenPipeException
with the specified detail message.
- BrokenPipeException(Throwable) - Constructor for exception org.xnio.BrokenPipeException
-
Constructs a BrokenPipeException
with the specified cause.
- BrokenPipeException(String, Throwable) - Constructor for exception org.xnio.BrokenPipeException
-
Constructs a BrokenPipeException
with the specified detail message and cause.
- 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.
- BufferedStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit that buffers output data.
- BufferedStreamSinkConduit(StreamSinkConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.BufferedStreamSinkConduit
-
Construct a new instance.
- BufferedStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which buffers input.
- BufferedStreamSourceConduit(StreamSourceConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.BufferedStreamSourceConduit
-
Construct a new instance.
- bufferFreed() - Method in interface org.xnio._private.Messages
-
- bufferOverflow() - Method in interface org.xnio._private.Messages
-
- 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
-
- BufferPipeOutputStream - Class in org.xnio.streams
-
An OutputStream
implementation which writes out ByteBuffer
s to a consumer.
- BufferPipeOutputStream(BufferPipeOutputStream.BufferWriter) - Constructor for class org.xnio.streams.BufferPipeOutputStream
-
Construct a new instance.
- BufferPipeOutputStream.BufferWriter - Interface in org.xnio.streams
-
- Buffers - Class in org.xnio
-
Buffer utility methods.
- bufferUnderflow() - Method in interface org.xnio._private.Messages
-
- 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, int) - Constructor for class org.xnio.ByteBufferSlicePool
-
Construct a new instance.
- 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.
- callNext(T) - Method in class org.xnio.DelegatingChannelListener
-
Call the next listener.
- cancel() - Method in class org.xnio.AbstractConvertingIoFuture
-
- cancel() - Method in class org.xnio.AbstractIoFuture
-
Cancel an operation.
- cancel() - Method in interface org.xnio.Cancellable
-
Cancel an operation.
- cancel() - Method in class org.xnio.FailedIoFuture
-
Cancel the operation.
- cancel() - Method in class org.xnio.FinishedIoFuture
-
Cancel the operation.
- cancel() - Method in interface org.xnio.IoFuture
-
Cancel an operation.
- Cancellable - Interface in org.xnio
-
An operation which may be cancelled.
- cantInstantiate(Class<?>, Throwable) - Method in interface org.xnio._private.Messages
-
- 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(Object, T) - 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.
- ChainedChannelListener<T extends Channel> - Class in org.xnio
-
A channel listener that chains calls to a number of other channel listeners.
- ChainedChannelListener(ChannelListener<? super T>...) - Constructor for class org.xnio.ChainedChannelListener
-
Construct a new instance.
- channel - Variable in class org.xnio.channels.TranslatingSuspendableChannel
-
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.
- ChannelExceptionHandler<T extends Channel> - Interface in org.xnio
-
An exception handler for utility channel listeners.
- ChannelFactory<C extends Channel> - Interface in org.xnio.channels
-
A generalized channel factory type.
- ChannelInputStream - Class in org.xnio.streams
-
An input stream which reads from a stream source channel.
- ChannelInputStream(StreamSourceChannel) - Constructor for class org.xnio.streams.ChannelInputStream
-
Construct a new instance.
- ChannelInputStream(StreamSourceChannel, long, TimeUnit) - Constructor for class org.xnio.streams.ChannelInputStream
-
Construct a new instance.
- ChannelListener<T 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
-
- 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.
- channelNotAvailable() - Method in interface org.xnio._private.Messages
-
- ChannelOutputStream - Class in org.xnio.streams
-
An output stream which writes to a stream sink channel.
- ChannelOutputStream(StreamSinkChannel) - Constructor for class org.xnio.streams.ChannelOutputStream
-
Construct a new instance.
- ChannelOutputStream(StreamSinkChannel, long, TimeUnit) - Constructor for class org.xnio.streams.ChannelOutputStream
-
Construct a new instance.
- ChannelPipe<L extends CloseableChannel,R extends CloseableChannel> - Class in org.xnio
-
A one-way pipe.
- ChannelPipe(L, R) - Constructor for class org.xnio.ChannelPipe
-
Construct a new instance.
- Channels - Class in org.xnio.channels
-
A utility class containing static methods to support channel usage.
- ChannelSource<T extends Channel> - Interface in org.xnio
-
A channel source.
- characterDecodingProblem() - Method in interface org.xnio._private.Messages
-
- charFromBytesBE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed big-endian char value from a byte array.
- charFromBytesLE(byte[], int) - Static method in class org.xnio.Bits
-
Get a 16-bit signed little-endian char value from a byte array.
- checkBlockingAllowed() - Static method in class org.xnio.Xnio
-
Perform a check for whether blocking is allowed on the current thread.
- checkHandshake(Map<String, String>) - Method in interface org.xnio.http.HandshakeChecker
-
Checks a handshake, and throws an exception if it is invalid
- chooseThread() - Method in class org.xnio.XnioWorker
-
Choose a thread randomly from this worker.
- classNotFound(String, ClassNotFoundException) - Method in interface org.xnio._private.Messages
-
- classNotInstance(String, Class<?>) - Method in interface org.xnio._private.Messages
-
- clear() - Method in class org.xnio.AutomaticReference
-
Not supported.
- 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.
- clone() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Duplicate this channel.
- clone() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Duplicate this channel.
- close() - Method in class org.xnio.channels.AssembledChannel
-
- close() - Method in class org.xnio.channels.AssembledMessageChannel
-
- close() - Method in class org.xnio.channels.AssembledStreamChannel
-
- close() - Method in class org.xnio.channels.BlockingByteChannel
- close() - Method in class org.xnio.channels.BlockingReadableByteChannel
- close() - Method in class org.xnio.channels.BlockingWritableByteChannel
- close() - Method in interface org.xnio.channels.CloseableChannel
-
Close this channel.
- close() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- close() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- close() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- close() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- close() - Method in class org.xnio.channels.PushBackStreamChannel
-
- close() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- close() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- close() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Close this channel.
- close() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Close this channel.
- close() - Method in class org.xnio.conduits.ConduitReadableByteChannel
-
- close() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- close() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- close() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- close() - Method in class org.xnio.conduits.ConduitWritableByteChannel
-
- close() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- close() - Method in class org.xnio.Connection
-
- close() - Method in 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
-
- 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
-
- closeAction() - Method in class org.xnio.Connection
-
- 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.
- CloseListenerSettable<C extends Channel> - Interface in org.xnio.channels
-
An object which supports directly setting the close listener may implement this interface.
- CloseListenerSettable.Setter<C extends Channel> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- CloseListenerSettable.Setter(CloseListenerSettable<C>) - Constructor for class org.xnio.channels.CloseListenerSettable.Setter
-
Construct a new instance.
- closeMsg - Static variable in interface org.xnio._private.Messages
-
- Closer - Class in org.xnio
-
A Runnable
that closes some resource.
- Closer(Closeable) - Constructor for class org.xnio.Closer
-
- closingCancellable(Closeable) - Static method in class org.xnio.IoUtils
-
A cancellable which closes the given resource on cancel.
- closingChannelExceptionHandler() - Static method in class org.xnio.ChannelListeners
-
Get a channel exception handler which closes the channel upon exception.
- closingChannelListener() - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the channel when notified.
- closingChannelListener(Closeable) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingChannelListener(Closeable...) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resources when notified.
- closingChannelListener(ChannelListener<T>, Closeable) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingChannelListener(ChannelListener<T>, Closeable...) - Static method in class org.xnio.ChannelListeners
-
Get a channel listener which closes the given resource when notified.
- closingNotifier() - Static method in class org.xnio.IoUtils
-
Get a notifier that closes the result.
- closingResource(Object) - Method in interface org.xnio._private.Messages
-
- compareTo(ByteString) - Method in class org.xnio.ByteString
-
Compare this ByteString to another.
- COMPRESSION_LEVEL - Static variable in class org.xnio.Options
-
The compression level to apply for compressing streams and channels.
- COMPRESSION_TYPE - Static variable in class org.xnio.Options
-
The compression type to apply for compressing streams and channels.
- CompressionType - Enum in org.xnio
-
Supported compression types.
- concurrentAccess() - Method in interface org.xnio._private.Messages
-
- ConcurrentStreamChannelAccessException - Exception in org.xnio.channels
-
An exception which is thrown when more than one thread tries to access a stream channel at once.
- ConcurrentStreamChannelAccessException() - Constructor for exception org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a ConcurrentStreamChannelAccessException
with no detail message.
- ConcurrentStreamChannelAccessException(String) - Constructor for exception org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a ConcurrentStreamChannelAccessException
with the specified detail message.
- ConcurrentStreamChannelAccessException(Throwable) - Constructor for exception org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a ConcurrentStreamChannelAccessException
with the specified cause.
- ConcurrentStreamChannelAccessException(String, Throwable) - Constructor for exception org.xnio.channels.ConcurrentStreamChannelAccessException
-
Constructs a ConcurrentStreamChannelAccessException
with the specified detail message and cause.
- Conduit - Interface in org.xnio.conduits
-
A conduit, or stage which data transfer is processed by or provided by.
- ConduitReadableByteChannel - Class in org.xnio.conduits
-
A byte channel which wraps a conduit.
- ConduitReadableByteChannel(StreamSourceConduit) - Constructor for class org.xnio.conduits.ConduitReadableByteChannel
-
Construct a new instance.
- ConduitReadableMessageChannel - Class in org.xnio.conduits
-
A readable message channel which is backed by a message source conduit.
- ConduitReadableMessageChannel(Configurable, MessageSourceConduit) - Constructor for class org.xnio.conduits.ConduitReadableMessageChannel
-
Construct a new instance.
- Conduits - Class in org.xnio.conduits
-
General utility methods for manipulating conduits.
- Conduits() - Constructor for class org.xnio.conduits.Conduits
-
- ConduitStreamSinkChannel - Class in org.xnio.conduits
-
A stream sink channel which wraps a stream sink conduit.
- ConduitStreamSinkChannel(Configurable, StreamSinkConduit) - Constructor for class org.xnio.conduits.ConduitStreamSinkChannel
-
Construct a new instance.
- ConduitStreamSourceChannel - Class in org.xnio.conduits
-
A stream source channel which wraps a stream source conduit.
- ConduitStreamSourceChannel(Configurable, StreamSourceConduit) - Constructor for class org.xnio.conduits.ConduitStreamSourceChannel
-
Construct a new instance.
- ConduitWritableByteChannel - Class in org.xnio.conduits
-
A byte channel which wraps a conduit.
- ConduitWritableByteChannel(StreamSinkConduit) - Constructor for class org.xnio.conduits.ConduitWritableByteChannel
-
Construct a new instance.
- ConduitWritableMessageChannel - Class in org.xnio.conduits
-
A writable message channel which is backed by a message sink conduit.
- ConduitWritableMessageChannel(Configurable, MessageSinkConduit) - Constructor for class org.xnio.conduits.ConduitWritableMessageChannel
-
Construct a new instance.
- Configurable - Interface in org.xnio.channels
-
A channel that has parameters that may be configured while the channel is open.
- connectDatagram(SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectDatagram(SocketAddress, SocketAddress, ChannelListener<? super ConnectedMessageChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- ConnectedChannel - Interface in org.xnio.channels
-
A channel that has a local and peer endpoint address.
- ConnectedMessageChannel - Interface in org.xnio.channels
-
A channel that sends and receives messages to a connected peer.
- ConnectedSslStreamChannel - Interface in org.xnio.channels
-
A TLS-encapsulated connected stream channel.
- ConnectedStreamChannel - Interface in org.xnio.channels
-
A stream channel that is a connection between a local and remote endpoint.
- Connection - Class in org.xnio
-
The base for all connections.
- Connection(XnioIoThread) - Constructor for class org.xnio.Connection
-
Construct a new instance.
- CONNECTION_HIGH_WATER - Static variable in class org.xnio.Options
-
The high water mark for a server's connections.
- CONNECTION_LOW_WATER - Static variable in class org.xnio.Options
-
The low water mark for a server's connections.
- connectionClosedEarly() - Method in interface org.xnio._private.Messages
-
- 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
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectSsl(XnioWorker, InetSocketAddress, InetSocketAddress, ChannelListener<? super ConnectedSslStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Deprecated.
- connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectStream(SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- connectStream(SocketAddress, SocketAddress, ChannelListener<? super ConnectedStreamChannel>, ChannelListener<? super BoundChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- 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.
- copyNegative() - Method in interface org.xnio._private.Messages
-
- 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 interface org.xnio.channels.ChannelFactory
-
Create the channel instance.
- 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.
- createFileSystemWatcher(String, OptionMap) - Method in class org.xnio.Xnio
-
Creates a file system watcher, that can be used to monitor file system changes.
- createFullDuplexPipe() - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipe() - Method in class org.xnio.XnioIoThread
-
- createFullDuplexPipe() - Method in class org.xnio.XnioWorker
-
- createFullDuplexPipeConnection() - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipeConnection(XnioIoFactory) - Method in interface org.xnio.XnioIoFactory
-
Create a two-way stream pipe.
- createFullDuplexPipeConnection() - Method in class org.xnio.XnioIoThread
-
- createFullDuplexPipeConnection(XnioIoFactory) - Method in class org.xnio.XnioIoThread
-
- createFullDuplexPipeConnection() - Method in class org.xnio.XnioWorker
-
- createFullDuplexPipeConnection(XnioIoFactory) - Method in class org.xnio.XnioWorker
-
- createHalfDuplexPipe() - Method in interface org.xnio.XnioIoFactory
-
Create a one-way stream pipe.
- createHalfDuplexPipe(XnioIoFactory) - Method in interface org.xnio.XnioIoFactory
-
Create a one-way stream pipe.
- createHalfDuplexPipe() - Method in class org.xnio.XnioIoThread
-
- createHalfDuplexPipe(XnioIoFactory) - Method in class org.xnio.XnioIoThread
-
- createHalfDuplexPipe() - Method in class org.xnio.XnioWorker
-
- createHalfDuplexPipe(XnioIoFactory) - Method in class org.xnio.XnioWorker
-
- createLocalStreamConnectionServer(LocalSocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Implementation helper method to create a UNIX domain stream server.
- createOneWayPipe(ChannelListener<? super StreamSourceChannel>, ChannelListener<? super StreamSinkChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
- createPipe(ChannelListener<? super StreamChannel>, ChannelListener<? super StreamChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
- createPropertyMap(OptionMap, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Create a SASL property map from an XNIO option map.
- createSslConnectionServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<SslConnection>>, OptionMap) - Method in class org.xnio.ssl.JsseXnioSsl
-
- createSslConnectionServer(XnioWorker, InetSocketAddress, ChannelListener<? super AcceptingChannel<SslConnection>>, OptionMap) - Method in class org.xnio.ssl.XnioSsl
-
Create a bound TCP SSL server.
- createSSLContext(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
-
Deprecated.
- createStreamConnectionServer(SocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream server, for TCP or UNIX domain servers.
- createStreamServer(SocketAddress, ChannelListener<? super AcceptingChannel<ConnectedStreamChannel>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Deprecated.
- createTcpConnectionServer(InetSocketAddress, ChannelListener<? super AcceptingChannel<StreamConnection>>, OptionMap) - Method in class org.xnio.XnioWorker
-
Implementation helper method to create a TCP stream server.
- createUdpServer(InetSocketAddress, ChannelListener<? super MulticastMessageChannel>, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a UDP server.
- createUdpServer(InetSocketAddress, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a UDP server.
- createWorker(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.
- currentThread() - Static method in class org.xnio.XnioIoThread
-
Get the current XNIO thread.
- 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.
- failedToInvokeFileWatchCallback(Throwable) - Method in interface org.xnio._private.Messages
-
- fieldNotAccessible(String, Class<?>) - Method in interface org.xnio._private.Messages
-
- fieldNotStatic(String, Class<?>) - Method in interface org.xnio._private.Messages
-
- FILE_ACCESS - Static variable in class org.xnio.Options
-
The file access mode to use when opening a file.
- FILE_APPEND - Static variable in class org.xnio.Options
-
A flag which indicates that opened files should be appended to.
- FILE_CREATE - Static variable in class org.xnio.Options
-
A flag which indicates that a file should be created if it does not exist (true
by default for writing files,
false
by default for reading files).
- FileAccess - Enum in org.xnio
-
Possible file access modes.
- FileChangeCallback - Interface in org.xnio
-
Callback for file system change events
- FileChangeEvent - Class in org.xnio
-
The event object that is fired when a file system change is detected.
- FileChangeEvent(File, FileChangeEvent.Type) - Constructor for class org.xnio.FileChangeEvent
-
Construct a new instance.
- FileChangeEvent.Type - Enum in org.xnio
-
Watched file event types.
- FileChannel - Class in java.nio.channels
-
Compatibility stub.
- FileChannel() - Constructor for class java.nio.channels.FileChannel
-
- FileChannel.MapMode - Class in java.nio.channels
-
- FileChannel.MapMode() - Constructor for class java.nio.channels.FileChannel.MapMode
-
- fileReceivingChannelListener(FileChannel, long, long, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A file-receiving channel listener.
- fileSendingChannelListener(FileChannel, long, long, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A file-sending channel listener.
- FileSystemWatcher - Interface in org.xnio
-
File system watcher service.
- fill(ByteBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(CharBuffer, int, int) - Static method in class org.xnio.Buffers
-
Fill a buffer with a repeated value.
- fill(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.
- fillFromStream(ByteBuffer, InputStream) - Static method in class org.xnio.Buffers
-
Fill a buffer from an input stream.
- FinishedIoFuture<T> - Class in org.xnio
-
An implementation of
IoFuture
that represents an immediately-successful operation.
- FinishedIoFuture(T) - Constructor for class org.xnio.FinishedIoFuture
-
Create an instance.
- FixedLengthOverflowException - Exception in org.xnio.channels
-
Exception thrown when a fixed-length write channel is written beyond its full length.
- FixedLengthOverflowException() - Constructor for exception org.xnio.channels.FixedLengthOverflowException
-
Constructs a FixedLengthOverflowException
with no detail message.
- FixedLengthOverflowException(String) - Constructor for exception org.xnio.channels.FixedLengthOverflowException
-
Constructs a FixedLengthOverflowException
with the specified detail message.
- FixedLengthOverflowException(Throwable) - Constructor for exception org.xnio.channels.FixedLengthOverflowException
-
Constructs a FixedLengthOverflowException
with the specified cause.
- FixedLengthOverflowException(String, Throwable) - Constructor for exception org.xnio.channels.FixedLengthOverflowException
-
Constructs a FixedLengthOverflowException
with the specified detail message and cause.
- FixedLengthStreamSinkChannel - Class in org.xnio.channels
-
A channel which writes a fixed amount of data.
- FixedLengthStreamSinkChannel(StreamSinkChannel, long, boolean, boolean, ChannelListener<? super FixedLengthStreamSinkChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSinkChannel
-
Construct a new instance.
- FixedLengthStreamSinkConduit - Class in org.xnio.conduits
-
A stream sink conduit with a limited length.
- FixedLengthStreamSinkConduit(FixedLengthStreamSinkConduit) - Constructor for class org.xnio.conduits.FixedLengthStreamSinkConduit
-
Construct a new instance.
- FixedLengthStreamSourceChannel - Class in org.xnio.channels
-
A channel which reads data of a fixed length and calls a finish listener.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, boolean, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceChannel(StreamSourceChannel, long, boolean, boolean, ChannelListener<? super FixedLengthStreamSourceChannel>, Object) - Constructor for class org.xnio.channels.FixedLengthStreamSourceChannel
-
Construct a new instance.
- FixedLengthStreamSourceConduit - Class in org.xnio.conduits
-
A stream source conduit which limits the length of input.
- FixedLengthStreamSourceConduit(StreamSourceConduit, long) - Constructor for class org.xnio.conduits.FixedLengthStreamSourceConduit
-
Construct a new instance.
- FixedLengthUnderflowException - Exception in org.xnio.channels
-
Exception thrown when a fixed-length write channel is not written to its full length.
- FixedLengthUnderflowException() - Constructor for exception org.xnio.channels.FixedLengthUnderflowException
-
Constructs a UnfinishedWriteException
with no detail message.
- FixedLengthUnderflowException(String) - Constructor for exception org.xnio.channels.FixedLengthUnderflowException
-
Constructs a UnfinishedWriteException
with the specified detail message.
- FixedLengthUnderflowException(Throwable) - Constructor for exception org.xnio.channels.FixedLengthUnderflowException
-
Constructs a UnfinishedWriteException
with the specified cause.
- FixedLengthUnderflowException(String, Throwable) - Constructor for exception org.xnio.channels.FixedLengthUnderflowException
-
Constructs a UnfinishedWriteException
with the specified detail message and cause.
- fixedOverflow() - Method in interface org.xnio._private.Messages
-
- fixedUnderflow(long) - Method in interface org.xnio._private.Messages
-
- flip(T) - Static method in class org.xnio.Buffers
-
Flip a buffer.
- flush() - Method in class org.xnio.channels.AssembledMessageChannel
-
- flush() - Method in class org.xnio.channels.AssembledStreamChannel
-
- flush() - Method in class org.xnio.channels.BlockingByteChannel
- flush() - Method in class org.xnio.channels.BlockingWritableByteChannel
- flush() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- flush() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- flush() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- flush() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Flush any waiting partial send or write.
- flush() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Perform channel flush.
- flush() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- flush() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- flush() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- flush() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- flush() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- flush() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- flush() - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- flush() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- flush() - Method in interface org.xnio.conduits.SinkConduit
-
Flush out any unwritten, buffered output.
- flush() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- flush() - Method in class org.xnio.sasl.SaslUnwrappingConduit
-
- flush() - Method in class org.xnio.sasl.SaslWrappingConduit
-
- flush() - Method in interface org.xnio.streams.BufferPipeOutputStream.BufferWriter
-
Flushes this stream by writing any buffered output to the underlying stream.
- flush() - Method in class org.xnio.streams.BufferPipeOutputStream
- flush() - Method in class org.xnio.streams.ChannelOutputStream
- flush() - Method in class org.xnio.streams.LimitedOutputStream
- flush() - Method in class org.xnio.streams.WriterOutputStream
- flushAction(boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
- 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.
- flushingChannelListener(ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A flushing channel listener.
- flushSmallBuffer() - Method in interface org.xnio._private.Messages
-
- force(boolean) - Method in class java.nio.channels.FileChannel
-
- forceTermination() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
-
- forceTermination() - Method in class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
-
- forceTermination() - Method in interface org.xnio.conduits.TerminateHandler
-
Force the front-end channel to close, in response to XNIO worker shutdown.
- forceTermination() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
-
- FramedMessageChannel - Class in org.xnio.channels
-
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.
- FramingMessageSinkConduit - Class in org.xnio.conduits
-
A message sink conduit which implements a simple message framing protocol over a stream conduit.
- FramingMessageSinkConduit(StreamSinkConduit, boolean, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.FramingMessageSinkConduit
-
Construct a new instance.
- FramingMessageSourceConduit - Class in org.xnio.conduits
-
A message source conduit which implements a simple message framing protocol over a stream conduit.
- FramingMessageSourceConduit(StreamSourceConduit, Pooled<ByteBuffer>) - Constructor for class org.xnio.conduits.FramingMessageSourceConduit
-
Construct a new instance.
- free() - Method in class org.xnio.AutomaticReference
-
Free this reference.
- 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.
- futureMsg - Static variable in interface org.xnio._private.Messages
-
- 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.
- get() - Method in class org.xnio.AbstractConvertingIoFuture
-
- get() - Method in class org.xnio.AbstractIoFuture
-
Get the result of the operation.
- get() - Method in class org.xnio.AutomaticReference
-
Always returns null
.
- get() - Method in class org.xnio.ChannelListener.SimpleSetter
-
Get the channel listener set on this setter.
- get() - Method in class org.xnio.FinishedIoFuture
-
- get() - Method in interface org.xnio.IoFuture
-
Get the result of the operation.
- get(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.
- getAcceptListener() - Method in interface org.xnio.channels.AcceptListenerSettable
-
Get the accept listener.
- getAcceptSetter() - Method in interface org.xnio.channels.AcceptingChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptSetter() - Method in interface org.xnio.channels.SimpleAcceptingChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptSetter() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Get the setter which can be used to change the accept listener for this channel.
- getAcceptThread() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
- getAttachment(Class<T>) - Method in class org.xnio.Connection
-
Get a strongly-typed attachment of the given type.
- 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(Object) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getChannel(Object) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- 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(Object) - Method in interface org.xnio.channels.ProtectedWrappedChannel
-
Get the channel which is wrapped by this object, or null
if the guard is invalid.
- getChannel() - Method in class org.xnio.channels.PushBackStreamChannel
-
- 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.
- getChannelListenerTask(T, ChannelListener.SimpleSetter<T>) - Static method in class org.xnio.ChannelListeners
-
Get a task which invokes the given channel listener on the given channel via its setter.
- getCloseListener() - Method in interface org.xnio.channels.CloseListenerSettable
-
Get the close listener.
- getCloseListener() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getCloseListener() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getCloseListener() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getCloseListener() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getCloseListener() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getCloseListener() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getCloseListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- getCloseListener() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getCloseListener() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getCloseListener() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getCloseListener() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getCloseListener() - Method in class org.xnio.MessageConnection
-
- getCloseListener() - Method in class org.xnio.StreamConnection
-
- getCloseSetter() - Method in interface org.xnio.channels.AcceptingChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.AssembledChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledMessageChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledSslChannel
-
- getCloseSetter() - Method in class org.xnio.channels.AssembledStreamChannel
-
- getCloseSetter() - Method in interface org.xnio.channels.BoundChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.CloseableChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getCloseSetter() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getCloseSetter() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getCloseSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getCloseSetter() - Method in class org.xnio.channels.PushBackStreamChannel
-
- getCloseSetter() - Method in interface org.xnio.channels.ReadableMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SimpleAcceptingChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getCloseSetter() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getCloseSetter() - Method in interface org.xnio.channels.SslChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamSinkChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.StreamSourceChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.WritableMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getCloseSetter() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getCloseSetter() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getCloseSetter() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getCloseSetter() - Method in class org.xnio.MessageConnection
-
- getCloseSetter() - Method in class org.xnio.ssl.SslConnection
-
Get the setter which can be used to change the close listener for this channel.
- getCloseSetter() - Method in class org.xnio.StreamConnection
-
- getConduit() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Get the underlying conduit for this channel.
- getConduit() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Get the underlying conduit for this channel.
- getDeflatingChannel(StreamSinkChannel, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream channel that compresses to the destination according to the configuration in the given option map.
- getDeflatingChannel(StreamSinkChannel, Deflater) - Method in class org.xnio.XnioWorker
-
Create a stream channel that compresses to the destination according to the configuration in the given inflater.
- 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 class org.xnio.FinishedIoFuture
-
- getException() - Method in interface org.xnio.IoFuture
-
Get the failure reason.
- getFile() - Method in class org.xnio.FileChangeEvent
-
Get the file which was being watched.
- getFuture(IoFuture<T>) - Static method in class org.xnio.IoUtils
-
Get a java.util.concurrent
-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 class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- getHandshakeSetter() - Method in class org.xnio.channels.AssembledSslChannel
-
- getHandshakeSetter() - Method in interface org.xnio.channels.SslChannel
-
Get the setter which can be used to change the handshake listener for this channel.
- getHandshakeSetter() - Method in class org.xnio.ssl.SslConnection
-
Get the setter which can be used to change the handshake listener for this channel.
- getIn() - Method in class org.xnio.streams.Pipe
-
Get the input (read) side of the pipe.
- getInflatingChannel(StreamSourceChannel, OptionMap) - Method in class org.xnio.XnioWorker
-
Create a stream channel that decompresses the source data according to the configuration in the given option map.
- getInflatingChannel(StreamSourceChannel, Inflater) - Method in class org.xnio.XnioWorker
-
Create a stream channel that decompresses the source data according to the configuration in the given inflater.
- 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 class org.xnio.FinishedIoFuture
-
- getInterruptibly() - Method in interface org.xnio.IoFuture
-
Get the result of the operation.
- getIoFuture() - Method in class org.xnio.FutureResult
-
Get the IoFuture
for this manager.
- getIoThread() - Method in class org.xnio.channels.AssembledChannel
-
- getIoThread() - Method in class org.xnio.channels.AssembledMessageChannel
-
- getIoThread() - Method in class org.xnio.channels.AssembledStreamChannel
-
- getIoThread() - Method in interface org.xnio.channels.CloseableChannel
-
Get the I/O thread associated with this channel.
- getIoThread() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getIoThread() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getIoThread() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getIoThread() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getIoThread() - Method in class org.xnio.channels.PushBackStreamChannel
-
- getIoThread() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getIoThread() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getIoThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the I/O thread associated with this channel.
- getIoThread() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getIoThread() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getIoThread() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getIoThread() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getIoThread() - Method in class org.xnio.Connection
-
- getIoThread() - Method in class org.xnio.XnioWorker
-
Get an I/O thread from this worker.
- getIoThreadCount() - Method in class org.xnio.XnioWorker
-
Get the number of I/O threads configured on this worker.
- getKey() - Method in class org.xnio.Property
-
Get the key of this key/value Property.
- getLeftSide() - Method in class org.xnio.ChannelPipe
-
Get the pipe source.
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedChannel
-
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedChannel
-
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getLocalAddress() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getLocalAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getLocalAddress() - Method in interface org.xnio.channels.BoundChannel
-
Get the local address that this channel is bound to.
- getLocalAddress(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.
- getLocalAddress(Class<A>) - Method in class org.xnio.Connection
-
- 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.
- getNumber() - Method in class org.xnio.XnioIoThread
-
Get the number of this thread.
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledMessageChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.AssembledStreamChannel
-
- getOption(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.EmptyStreamSourceChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.PushBackStreamChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getOption(Option<T>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the value of a channel option.
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getOption(Option<T>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getOption(Option<T>) - Method in class org.xnio.Connection
-
- getOption(Option<T>) - Method in class org.xnio.XnioWorker
-
- getOut() - Method in class org.xnio.streams.Pipe
-
Get the output (write) side of the pipe.
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedChannel
-
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedChannel
-
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getPeerAddress() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getPeerAddress(Class<A>) - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- 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.
- getPeerAddress(Class<A>) - Method in class org.xnio.Connection
-
- getPermit() - Static method in class org.xnio.AutomaticReference
-
Get the security authorization permit to create automatic references.
- 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.
- getReadListener() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getReadListener() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getReadListener() - Method in interface org.xnio.channels.ReadListenerSettable
-
Get the read listener.
- getReadListener() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getReadListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- getReadListener() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getReadListener() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- getReadSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getReadSetter() - Method in class org.xnio.channels.AssembledMessageChannel
-
- getReadSetter() - Method in class org.xnio.channels.AssembledStreamChannel
-
- getReadSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getReadSetter() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getReadSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.PushBackStreamChannel
-
- getReadSetter() - Method in interface org.xnio.channels.ReadableMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.ReadableMultipointMessageChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getReadSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.StreamSourceChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the setter which can be used to change the read listener for this channel.
- getReadSetter() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getReadSetter() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getReadThread() - Method in class org.xnio.channels.AssembledMessageChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.AssembledStreamChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.PushBackStreamChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in interface org.xnio.channels.SuspendableReadChannel
-
- getReadThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- getReadThread() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Deprecated.
- getReadThread() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- getReadThread() - Method in interface org.xnio.conduits.SourceConduit
-
Get the XNIO read thread.
- getReadThread() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- getReadTimeout(TimeUnit) - Method in class org.xnio.streams.BufferedChannelInputStream
-
Get the read timeout.
- getReadTimeout(TimeUnit) - Method in class org.xnio.streams.ChannelInputStream
-
Get the read timeout.
- getRemaining() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
Get the number of remaining bytes in this fixed length channel.
- getRemaining() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
Get the number of remaining bytes.
- getRemaining() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
Get the number of remaining bytes available to read.
- getRemaining() - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
Get the number of bytes which remain available to read.
- getResource() - Method in interface org.xnio.Pooled
-
Get the pooled resource.
- getRetryingChannelSource(ChannelSource<T>, int) - Static method in class org.xnio.IoUtils
-
A channel source which tries to acquire a channel from a delegate channel source the given number of times before
giving up.
- getRightSide() - Method in class org.xnio.ChannelPipe
-
Get the pipe sink.
- getSaslClientFactories(ClassLoader, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslClientFactory
s where the order is based on the
order of the Provider registration and/or class path order.
- getSaslClientFactories() - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslClientFactory
s where the order is based on the
order of the Provider registration and/or class path order.
- getSaslServerFactories(ClassLoader, boolean) - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslServerFactory
s where the order is based on the
order of the Provider registration and/or class path order.
- getSaslServerFactories() - Static method in class org.xnio.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslServerFactory
s where the order is based on the
order of the Provider registration and/or class path order.
- getSetter(C, AtomicReferenceFieldUpdater<C, ChannelListener>) - Static method in class org.xnio.ChannelListeners
-
Deprecated.
Not recommended as a security manager will enforce unreasonable restrictions on the updater.
- getSetter(AtomicReference<ChannelListener<? super T>>) - Static method in class org.xnio.ChannelListeners
-
Get a setter based on an atomic reference.
- getSinkChannel() - Method in class org.xnio.MessageConnection
-
Get the sink channel.
- getSinkChannel() - Method in class org.xnio.StreamConnection
-
Get the sink channel.
- getSourceAddress() - Method in interface org.xnio.channels.MulticastMessageChannel.Key
-
Return the source address if this membership key is source specific, or null
if this membership is not
source specific.
- getSourceAddress() - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the source address.
- getSourceAddress(Class<A>) - Method in class org.xnio.channels.SocketAddressBuffer
-
Get the source address.
- getSourceChannel() - Method in class org.xnio.MessageConnection
-
Get the source channel.
- getSourceChannel() - Method in class org.xnio.StreamConnection
-
Get the source channel.
- getSslContext() - Method in class org.xnio.ssl.JsseXnioSsl
-
Get the JSSE SSL context for this provider instance.
- getSslEngine(SslConnection) - Static method in class org.xnio.ssl.JsseXnioSsl
-
Get the SSL engine for a given connection.
- getSslProvider(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 class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- getSslSession() - Method in class org.xnio.channels.AssembledSslChannel
-
- getSslSession() - Method in interface org.xnio.channels.SslChannel
-
Get the current SSLSession
for this channel.
- getSslSession() - Method in class org.xnio.ssl.SslConnection
-
Get the current SSLSession
for this channel.
- getStatus() - Method in class org.xnio.AbstractConvertingIoFuture
-
- getStatus() - Method in class org.xnio.AbstractIoFuture
-
Get the current status.
- getStatus() - Method in class org.xnio.FinishedIoFuture
-
- getStatus() - Method in interface org.xnio.IoFuture
-
Get the current status.
- 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.
- getType() - Method in class org.xnio.FileChangeEvent
-
Get the type of event.
- getValue() - Method in class org.xnio.Property
-
Get the value of this key/value Property.
- getVersionString() - Static method in class org.xnio.Version
-
Get the version string.
- getWorker() - Method in class org.xnio.channels.AssembledChannel
-
- getWorker() - Method in class org.xnio.channels.AssembledMessageChannel
-
- getWorker() - Method in class org.xnio.channels.AssembledStreamChannel
-
- getWorker() - Method in interface org.xnio.channels.CloseableChannel
-
Get the worker for this channel.
- getWorker() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- getWorker() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getWorker() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- getWorker() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getWorker() - Method in class org.xnio.channels.PushBackStreamChannel
-
- getWorker() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getWorker() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- getWorker() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the worker for this channel.
- getWorker() - Method in class org.xnio.conduits.AbstractConduit
-
- getWorker() - Method in interface org.xnio.conduits.Conduit
-
Get the XNIO worker associated with this conduit.
- getWorker() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- getWorker() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getWorker() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- getWorker() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getWorker() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- getWorker() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- getWorker() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- getWorker() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- getWorker() - Method in class org.xnio.Connection
-
- getWorker() - Method in class org.xnio.XnioIoThread
-
Get the XNIO worker associated with this thread.
- getWriteListener() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getWriteListener() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getWriteListener() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getWriteListener() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- getWriteListener() - Method in interface org.xnio.channels.WriteListenerSettable
-
Get the write listener.
- getWriteListener() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getWriteListener() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedMessageChannel
-
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- getWriteSetter() - Method in class org.xnio.channels.AssembledConnectedStreamChannel
-
- getWriteSetter() - Method in class org.xnio.channels.AssembledMessageChannel
-
- getWriteSetter() - Method in class org.xnio.channels.AssembledStreamChannel
-
- getWriteSetter() - Method in interface org.xnio.channels.BoundMultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedSslStreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.ConnectedStreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- getWriteSetter() - Method in interface org.xnio.channels.MessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.MulticastMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.MultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- getWriteSetter() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- getWriteSetter() - Method in interface org.xnio.channels.StreamChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.StreamSinkChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.SuspendableChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.WritableMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Get the setter which can be used to change the write listener for this channel.
- getWriteSetter() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- getWriteSetter() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- getWriteThread() - Method in class org.xnio.channels.AssembledMessageChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.AssembledStreamChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.NullStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
- getWriteThread() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- getWriteThread() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Deprecated.
- getWriteThread() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- getWriteThread() - Method in interface org.xnio.conduits.SinkConduit
-
Get the write thread for this conduit.
- getWriteThread() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- getWriteTimeout(TimeUnit) - Method in class org.xnio.streams.ChannelOutputStream
-
Get the write timeout.
- getXnio() - Method in class org.xnio.XnioWorker
-
Get the XNIO provider which produced this worker.
- greeting(String) - Method in interface org.xnio._private.Messages
-
- randomWrongThread() - Method in interface org.xnio._private.Messages
-
- read(ByteBuffer) - Method in class java.nio.channels.FileChannel
-
- read(ByteBuffer[], int, int) - Method in class java.nio.channels.FileChannel
-
- read(ByteBuffer[]) - Method in class java.nio.channels.FileChannel
-
- read(ByteBuffer, long) - Method in class java.nio.channels.FileChannel
-
- read(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, scattering read operation.
- read(ByteBuffer[]) - 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(ByteBuffer[], int, int) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.channels.PushBackStreamChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.channels.PushBackStreamChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.PushBackStreamChannel
-
- read(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.ConduitReadableByteChannel
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- read(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- read(ByteBuffer) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- read(ByteBuffer[]) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- read(ByteBuffer) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- read(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- read(ByteBuffer) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Read a sequence of bytes from this conduit to the given buffer.
- read(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Read a sequence of bytes from this conduit to the given buffers.
- 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_ONLY - Static variable in class java.nio.channels.FileChannel.MapMode
-
- READ_TIMEOUT - Static variable in class org.xnio.Options
-
Configure a read timeout for a socket, in milliseconds.
- READ_WRITE - Static variable in class java.nio.channels.FileChannel.MapMode
-
- ReadableMessageChannel - Interface in org.xnio.channels
-
A channel that can receive messages.
- ReadableMultipointMessageChannel - Interface in org.xnio.channels
-
The readable side of a multipoint message channel.
- readAppendNotSupported() - Method in interface org.xnio._private.Messages
-
- 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.
- readClosed() - Method in class org.xnio.Connection
-
- ReaderInputStream - Class in org.xnio.streams
-
An input stream which encodes characters into bytes.
- ReaderInputStream(Reader) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, String) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, Charset) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, CharsetEncoder) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- ReaderInputStream(Reader, CharsetEncoder, int) - Constructor for class org.xnio.streams.ReaderInputStream
-
Construct a new instance.
- readLatin1(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read the remainder of a buffer as Latin-1 text, appending the results to the given string
builder.
- readLatin1Line(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a single line of Latin-1 text from a byte buffer, appending the results to the given string
builder.
- readLatin1Line(ByteBuffer, StringBuilder, char) - Static method in class org.xnio.Buffers
-
Read a single line of Latin-1 text from a byte buffer, appending the results to the given string
builder.
- readLatin1Z(ByteBuffer, StringBuilder) - Static method in class org.xnio.Buffers
-
Read a NUL
-terminated Latin-1 string from a byte buffer, appending the results to the given string
builder.
- readLine(ByteBuffer, StringBuilder, CharsetDecoder) - Static method in class org.xnio.Buffers
-
Read a single line of text from a byte buffer, appending the results to the given string
builder.
- readLine(ByteBuffer, StringBuilder, CharsetDecoder, char) - Static method in class org.xnio.Buffers
-
Read a single line of text from a byte buffer, appending the results to the given string
builder.
- ReadListenerSettable<C extends Channel> - Interface in org.xnio.channels
-
An object which supports directly setting the read listener may implement this interface.
- ReadListenerSettable.Setter<C extends Channel> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- ReadListenerSettable.Setter(ReadListenerSettable<C>) - Constructor for class org.xnio.channels.ReadListenerSettable.Setter
-
Construct a new instance.
- 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.
- readOnlyBuffer() - Method in interface org.xnio._private.Messages
-
- ReadPropertyAction - Class in org.xnio
-
A simple property-read privileged action.
- ReadPropertyAction(String, String) - Constructor for class org.xnio.ReadPropertyAction
-
Construct a new instance.
- readReady() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
-
- readReady() - Method in interface org.xnio.conduits.ReadReadyHandler
-
Signify that reads are ready.
- ReadReadyHandler - Interface in org.xnio.conduits
-
A conduit read-ready handler.
- ReadReadyHandler.ChannelListenerHandler<C extends SuspendableReadChannel & ReadListenerSettable<C> & CloseListenerSettable<C>> - Class in org.xnio.conduits
-
A read ready handler which calls channel listener(s).
- ReadReadyHandler.ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
-
Construct a new instance.
- ReadReadyHandler.ReadyTask - Class in org.xnio.conduits
-
- ReadReadyHandler.ReadyTask(ReadReadyHandler) - Constructor for class org.xnio.conduits.ReadReadyHandler.ReadyTask
-
Construct a new instance.
- 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.
- readSuspendingChannelListener(ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
A read-suspending channel listener.
- readTimeout() - Method in interface org.xnio._private.Messages
-
- 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.AssembledMessageChannel
-
- receive(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
-
- receive(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
-
- 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(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSourceConduit
-
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSourceConduit
-
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- receive(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- receive(ByteBuffer) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- receive(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- receive(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- receive(ByteBuffer) - Method in interface org.xnio.conduits.MessageSourceConduit
-
Receive a message.
- receive(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSourceConduit
-
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.
- recvInvalidMsgLength(int) - Method in interface org.xnio._private.Messages
-
- 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.
- requireCurrentThread() - Static method in class org.xnio.XnioIoThread
-
Get the current XNIO thread.
- reset(T) - Static method in class org.xnio.Buffers
-
Reset the buffer.
- reset() - Method in class org.xnio.streams.LimitedInputStream
- resourceCloseFailed(Throwable, Object) - Method in interface org.xnio._private.Messages
-
- resourceReadShutdownFailed(Throwable, Object) - Method in interface org.xnio._private.Messages
-
- Result<T> - Interface in org.xnio
-
A handler for the result of an operation.
- resultNotifier() - Static method in class org.xnio.IoUtils
-
Get the result notifier.
- resumeAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Resume reads on this channel.
- resumeReads() - Method in class org.xnio.channels.AssembledMessageChannel
-
- resumeReads() - Method in class org.xnio.channels.AssembledStreamChannel
-
- resumeReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- resumeReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- resumeReads() - Method in class org.xnio.channels.PushBackStreamChannel
-
- resumeReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- resumeReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Resume reads on this channel.
- resumeReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Resume reads on this channel.
- resumeReads() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- resumeReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- resumeReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- resumeReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- resumeReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- resumeReads() - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- resumeReads() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- resumeReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that the conduit's
ReadReadyHandler
should be invoked as soon as data can be read
without blocking.
- resumeReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- resumeReadsAsync(SuspendableReadChannel) - Static method in class org.xnio.channels.Channels
-
Resume reads asynchronously.
- resumeWrites() - Method in class org.xnio.channels.AssembledMessageChannel
-
- resumeWrites() - Method in class org.xnio.channels.AssembledStreamChannel
-
- resumeWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- resumeWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- resumeWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- resumeWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Resume writes on this channel.
- resumeWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Resume writes on this channel.
- resumeWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- resumeWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- resumeWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- resumeWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- resumeWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- resumeWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Indicate that the conduit's
WriteReadyHandler
should be invoked as soon as data can be written
without blocking.
- resumeWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- resumeWritesAsync(SuspendableWriteChannel) - Static method in class org.xnio.channels.Channels
-
Resume writes asynchronously.
- REUSE_ADDRESSES - Static variable in class org.xnio.Options
-
Configure an IP socket to reuse addresses.
- rewind(T) - Static method in class org.xnio.Buffers
-
Rewind the buffer.
- run() - Method in class org.xnio.Closer
-
- run() - Method in class org.xnio.conduits.ReadReadyHandler.ReadyTask
-
- run() - Method in class org.xnio.conduits.TerminateHandler.ReadyTask
-
- run() - Method in class org.xnio.conduits.WriteReadyHandler.ReadyTask
-
- run() - Method in class org.xnio.ReadPropertyAction
-
Run the action.
- runnableNotifier(Runnable) - Static method in class org.xnio.IoUtils
-
Get a notifier that runs the supplied action.
- runNotifier(Runnable) - Method in class org.xnio.AbstractIoFuture
-
Run a notifier.
- safeClose(Closeable) - Static method in class org.xnio.IoUtils
-
Close a resource, logging an error if an error occurs.
- safeClose(Closeable...) - Static method in class org.xnio.IoUtils
-
Close a series of resources, logging errors if they occur.
- safeClose(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.
- SaslUnwrappingConduit - Class in org.xnio.sasl
-
- SaslUnwrappingConduit(MessageSinkConduit, SaslWrapper) - Constructor for class org.xnio.sasl.SaslUnwrappingConduit
-
- SaslUtils - Class in org.xnio.sasl
-
Utility methods for handling SASL authentication using NIO-style programming methods.
- SaslWrapper - Class in org.xnio.sasl
-
A wrapper delegation class for SASL that presents the same wrap/unwrap API regardless of whether it is
dealing with a SASL client or server.
- SaslWrapper() - Constructor for class org.xnio.sasl.SaslWrapper
-
- SaslWrappingConduit - Class in org.xnio.sasl
-
- SaslWrappingConduit(MessageSinkConduit, SaslWrapper) - Constructor for class org.xnio.sasl.SaslWrappingConduit
-
- SECURE - Static variable in class org.xnio.Options
-
Determine whether the channel is encrypted, or employs some other level of security.
- secureBufferPool(Pool<ByteBuffer>) - Static method in class org.xnio.Buffers
-
A byte buffer pool which zeroes the content of the buffer before re-pooling it.
- send(ByteBuffer) - Method in class org.xnio.channels.AssembledMessageChannel
-
- send(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
-
- 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(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
-
- send(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- send(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- send(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- send(ByteBuffer) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- send(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- send(ByteBuffer) - Method in class org.xnio.sasl.SaslUnwrappingConduit
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslUnwrappingConduit
-
- send(ByteBuffer) - Method in class org.xnio.sasl.SaslWrappingConduit
-
- send(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslWrappingConduit
-
- SEND_BUFFER - Static variable in class org.xnio.Options
-
The send buffer size.
- sendBlocking(C, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Simple utility method to execute a blocking send on a message channel.
- sendBlocking(C, ByteBuffer, 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.
- sendFinal(ByteBuffer) - Method in class org.xnio.channels.AssembledMessageChannel
-
- sendFinal(ByteBuffer[]) - Method in class org.xnio.channels.AssembledMessageChannel
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledMessageChannel
-
- sendFinal(ByteBuffer) - Method in class org.xnio.channels.FramedMessageChannel
-
- sendFinal(ByteBuffer[]) - Method in class org.xnio.channels.FramedMessageChannel
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.FramedMessageChannel
-
- sendFinal(ByteBuffer) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer[]) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMessageChannel
-
Send a complete message.
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
-
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.AbstractMessageSinkConduit
-
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- sendFinal(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- sendFinal(ByteBuffer) - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- sendFinal(ByteBuffer) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- sendFinal(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.MessageSinkConduit
-
Send a complete message.
- sendFinal(ByteBuffer) - Method in class org.xnio.sasl.SaslUnwrappingConduit
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslUnwrappingConduit
-
- sendFinal(ByteBuffer) - Method in class org.xnio.sasl.SaslWrappingConduit
-
- sendFinal(ByteBuffer[], int, int) - Method in class org.xnio.sasl.SaslWrappingConduit
-
- sendFinalBasic(MessageSinkConduit, ByteBuffer) - Static method in class org.xnio.conduits.Conduits
-
Writes a message to the conduit, and terminates writes if the send was successfully.
- sendFinalBasic(MessageSinkConduit, ByteBuffer[], int, int) - Static method in class org.xnio.conduits.Conduits
-
Writes a message to the conduit, and terminates writes if the send was successfully.
- sendingChannelListener(Pooled<ByteBuffer>, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A sending channel listener.
- sendTo(SocketAddress, ByteBuffer) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a buffer to a destination.
- sendTo(SocketAddress, ByteBuffer[]) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a message with data from multiple buffers to a destination.
- sendTo(SocketAddress, ByteBuffer[], int, int) - Method in interface org.xnio.channels.WritableMultipointMessageChannel
-
Send a message with data from multiple buffers to a destination.
- sequence(Class<?>, String, Class<T>) - Static method in class org.xnio.Option
-
Create an option with a sequence type.
- Sequence<T> - Class in org.xnio
-
An immutable sequence of elements.
- set(ChannelListener<? super 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(ChannelListener<? super C>) - Method in class org.xnio.channels.AcceptListenerSettable.Setter
-
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.CloseListenerSettable.Setter
-
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.ReadListenerSettable.Setter
-
- set(ChannelListener<? super C>) - Method in class org.xnio.channels.WriteListenerSettable.Setter
-
- set(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(ChannelListener<? super C>) - Method in interface org.xnio.channels.AcceptListenerSettable
-
Set the accept listener.
- setAcceptListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the accept listener for a channel (type-safe).
- 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).
- setCloseListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.CloseListenerSettable
-
Set the close listener.
- setCloseListener(ChannelListener<? super EmptyStreamSourceChannel>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- setCloseListener(ChannelListener<? super FixedLengthStreamSinkChannel>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- setCloseListener(ChannelListener<? super FixedLengthStreamSourceChannel>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- setCloseListener(ChannelListener<? super NullStreamSinkChannel>) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- setCloseListener(ChannelListener<? super PushBackStreamChannel>) - Method in class org.xnio.channels.PushBackStreamChannel
-
- setCloseListener(ChannelListener<? super SplitStreamSinkChannel>) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- setCloseListener(ChannelListener<? super SplitStreamSourceChannel>) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- setCloseListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- setCloseListener(ChannelListener<? super ConduitReadableMessageChannel>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- setCloseListener(ChannelListener<? super ConduitStreamSinkChannel>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- setCloseListener(ChannelListener<? super ConduitStreamSourceChannel>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- setCloseListener(ChannelListener<? super ConduitWritableMessageChannel>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- setCloseListener(ChannelListener<? super MessageConnection>) - Method in class org.xnio.MessageConnection
-
- setCloseListener(ChannelListener<? super StreamConnection>) - Method in class org.xnio.StreamConnection
-
- setConduit(MessageSourceConduit) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
Set the underlying conduit for this channel.
- setConduit(StreamSinkConduit) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
Set the underlying conduit for this channel.
- setConduit(StreamSourceConduit) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
Set the underlying conduit for this channel.
- setConduit(MessageSinkConduit) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
Set the underlying conduit for this channel.
- 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 class org.xnio.channels.AssembledChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.AssembledMessageChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.AssembledStreamChannel
-
- setOption(Option<T>, T) - Method in interface org.xnio.channels.Configurable
-
Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.PushBackStreamChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Set an option for this channel.
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- setOption(Option<T>, T) - Method in class org.xnio.Connection
-
- setOption(Option<T>, T) - Method in class org.xnio.XnioWorker
-
- setReadListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the read listener for a channel (type-safe).
- setReadListener(ChannelListener<? super EmptyStreamSourceChannel>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- setReadListener(ChannelListener<? super FixedLengthStreamSourceChannel>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- setReadListener(ChannelListener<? super PushBackStreamChannel>) - Method in class org.xnio.channels.PushBackStreamChannel
-
- setReadListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.ReadListenerSettable
-
Set the read listener.
- setReadListener(ChannelListener<? super SplitStreamSourceChannel>) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- setReadListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- setReadListener(ChannelListener<? super ConduitReadableMessageChannel>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- setReadListener(ChannelListener<? super ConduitStreamSourceChannel>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- setReadReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Indicate that the channel is definitely immediately readable, regardless of the underlying channel state.
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.AbstractSourceConduit
-
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- setReadReadyHandler(ReadReadyHandler) - Method in interface org.xnio.conduits.SourceConduit
-
Set the handler which should receive readiness notifications.
- setReadReadyHandler(ReadReadyHandler) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- setReadRequiresWrite() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
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.
- setSinkConduit(MessageSinkConduit) - Method in class org.xnio.MessageConnection
-
- setSinkConduit(StreamSinkConduit) - Method in class org.xnio.StreamConnection
-
- setSourceAddress(SocketAddress) - Method in class org.xnio.channels.SocketAddressBuffer
-
Set the source address.
- setSourceConduit(MessageSourceConduit) - Method in class org.xnio.MessageConnection
-
- setSourceConduit(StreamSourceConduit) - Method in class org.xnio.StreamConnection
-
- setWriteListener(T, ChannelListener<? super T>) - Static method in class org.xnio.channels.Channels
-
Set the write listener for a channel (type-safe).
- setWriteListener(ChannelListener<? super FixedLengthStreamSinkChannel>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- setWriteListener(ChannelListener<? super NullStreamSinkChannel>) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- setWriteListener(ChannelListener<? super SplitStreamSinkChannel>) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- setWriteListener(ChannelListener<? super C>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
- setWriteListener(ChannelListener<? super C>) - Method in interface org.xnio.channels.WriteListenerSettable
-
Set the write listener.
- setWriteListener(ChannelListener<? super ConduitStreamSinkChannel>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- setWriteListener(ChannelListener<? super ConduitWritableMessageChannel>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- setWriteReady() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Indicate that the channel is definitely immediately writable, regardless of the underlying channel state.
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.AbstractSinkConduit
-
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- setWriteReadyHandler(WriteReadyHandler) - Method in interface org.xnio.conduits.SinkConduit
-
Set the handler which should receive readiness notifications.
- setWriteReadyHandler(WriteReadyHandler) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- setWriteRequiresRead() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
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
-
Shut down this worker.
- shutdownNow() - Method in class org.xnio.XnioWorker
-
Immediately terminate the worker.
- shutdownReads() - Method in class org.xnio.channels.AssembledMessageChannel
-
- shutdownReads() - Method in class org.xnio.channels.AssembledStreamChannel
-
- shutdownReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- shutdownReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- shutdownReads() - Method in class org.xnio.channels.PushBackStreamChannel
-
- shutdownReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- shutdownReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Places this readable channel at "end of stream".
- shutdownReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Perform the read shutdown action if it hasn't been performed already.
- shutdownReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- shutdownReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- shutdownReadsAction(boolean) - Method in class org.xnio.channels.FramedMessageChannel
-
- 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 class org.xnio.channels.AssembledMessageChannel
-
- shutdownWrites() - Method in class org.xnio.channels.AssembledStreamChannel
-
- shutdownWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- shutdownWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- shutdownWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- shutdownWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Indicate that writing is complete for this channel.
- shutdownWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Perform the write shutdown action if it hasn't been performed already.
- shutdownWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- shutdownWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- shutdownWritesAction() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
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.
- SinkConduit - Interface in org.xnio.conduits
-
A conduit which is a target or output for data.
- size() - Method in class java.nio.channels.FileChannel
-
- size() - Method in class org.xnio.OptionMap
-
Get the number of options stored in this map.
- size() - Method in class org.xnio.Sequence
-
Return the number of elements in this sequence.
- skip(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.ChannelInputStream
-
Skip bytes in the stream.
- 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.
- socketBufferTooSmall() - Method in interface org.xnio._private.Messages
-
- SourceConduit - Interface in org.xnio.conduits
-
- SplitStreamSinkChannel - Class in org.xnio.channels
-
A half-duplex (write side) wrapper for a full-duplex channel.
- SplitStreamSinkChannel(StreamSinkChannel, boolean) - Constructor for class org.xnio.channels.SplitStreamSinkChannel
-
Construct a new instance.
- SplitStreamSinkChannel(StreamSinkChannel) - Constructor for class org.xnio.channels.SplitStreamSinkChannel
-
Construct a new instance which does not delegate configuration.
- SplitStreamSourceChannel - Class in org.xnio.channels
-
A half-duplex (read side) wrapper for a full-duplex channel.
- SplitStreamSourceChannel(StreamSourceChannel, boolean) - Constructor for class org.xnio.channels.SplitStreamSourceChannel
-
Construct a new instance.
- SplitStreamSourceChannel(StreamSourceChannel) - Constructor for class org.xnio.channels.SplitStreamSourceChannel
-
Construct a new instance which doesn't delegate configuration.
- SSL_APPLICATION_BUFFER_REGION_SIZE - Static variable in class org.xnio.Options
-
The size of the allocation region to use for SSL application buffers.
- SSL_APPLICATION_BUFFER_SIZE - Static variable in class org.xnio.Options
-
The application buffer size for SSL.
- SSL_CLIENT_AUTH_MODE - Static variable in class org.xnio.Options
-
Specify the SSL client authentication mode.
- SSL_CLIENT_SESSION_CACHE_SIZE - Static variable in class org.xnio.Options
-
The size of the SSL client session cache.
- SSL_CLIENT_SESSION_TIMEOUT - Static variable in class org.xnio.Options
-
The SSL client session timeout (in seconds).
- SSL_ENABLE_SESSION_CREATION - Static variable in class org.xnio.Options
-
Enable or disable session creation for an SSL connection.
- SSL_ENABLED - Static variable in class org.xnio.Options
-
Specify whether SSL should be enabled.
- SSL_ENABLED_CIPHER_SUITES - Static variable in class org.xnio.Options
-
Specify the cipher suites for an SSL/TLS session.
- SSL_ENABLED_PROTOCOLS - Static variable in class org.xnio.Options
-
Specify the enabled protocols for an SSL/TLS session.
- SSL_JSSE_KEY_MANAGER_CLASSES - Static variable in class org.xnio.Options
-
The possible key manager classes to use for a JSSE SSL context.
- SSL_JSSE_TRUST_MANAGER_CLASSES - Static variable in class org.xnio.Options
-
The possible trust store classes to use for a JSSE SSL context.
- SSL_NON_BLOCKING_KEY_MANAGER - Static variable in class org.xnio.Options
-
Hint to the SSL engine that the key manager implementation(s) is/are non-blocking, so they can be executed
in the I/O thread, possibly improving performance by decreasing latency.
- SSL_NON_BLOCKING_TRUST_MANAGER - Static variable in class org.xnio.Options
-
Hint to the SSL engine that the trust manager implementation(s) is/are non-blocking, so they can be executed
in the I/O thread, possibly improving performance by decreasing latency.
- SSL_PACKET_BUFFER_REGION_SIZE - Static variable in class org.xnio.Options
-
The size of the allocation region to use for SSL packet buffers.
- SSL_PACKET_BUFFER_SIZE - Static variable in class org.xnio.Options
-
The packet buffer size for SSL.
- SSL_PEER_HOST_NAME - Static variable in class org.xnio.Options
-
Specify the (non-authoritative) name of the peer host to use for the purposes of session reuse, as well as
for the use of certain cipher suites (such as Kerberos).
- SSL_PEER_PORT - Static variable in class org.xnio.Options
-
Specify the (non-authoritative) port number of the peer port number to use for the purposes of session reuse, as well as
for the use of certain cipher suites.
- SSL_PROTOCOL - Static variable in class org.xnio.Options
-
Specify the protocol name for an SSL context.
- SSL_PROVIDER - Static variable in class org.xnio.Options
-
Specify the requested provider for an SSL/TLS session.
- SSL_RNG_OPTIONS - Static variable in class org.xnio.Options
-
The configuration of a secure RNG for SSL usage.
- SSL_SERVER_SESSION_CACHE_SIZE - Static variable in class org.xnio.Options
-
The size of the SSL server session cache.
- SSL_SERVER_SESSION_TIMEOUT - Static variable in class org.xnio.Options
-
The SSL server session timeout (in seconds).
- SSL_STARTTLS - Static variable in class org.xnio.Options
-
Specify whether to use STARTTLS mode (in which a connection starts clear and switches to TLS on demand).
- SSL_SUPPORTED_CIPHER_SUITES - Static variable in class org.xnio.Options
-
Get the supported cipher suites for an SSL/TLS session.
- SSL_SUPPORTED_PROTOCOLS - Static variable in class org.xnio.Options
-
Get the supported protocols for an SSL/TLS session.
- SSL_USE_CLIENT_MODE - Static variable in class org.xnio.Options
-
Specify whether SSL conversations should be in client or server mode.
- SslChannel - Interface in org.xnio.channels
-
A channel which can use SSL/TLS to negotiate a security layer.
- SslClientAuthMode - Enum in org.xnio
-
The desired SSL client authentication mode for SSL channels in server mode.
- SslConnection - Class in org.xnio.ssl
-
A stream connection which can use SSL/TLS to negotiate a security layer.
- SslConnection(XnioIoThread) - Constructor for class org.xnio.ssl.SslConnection
-
- sslContext - Variable in class org.xnio.ssl.XnioSsl
-
The SSL context for this instance.
- STACK_SIZE - Static variable in class org.xnio.Options
-
The stack size (in bytes) to attempt to use for worker threads.
- startHandshake() - Method in class org.xnio.channels.AssembledConnectedSslStreamChannel
-
- startHandshake() - Method in class org.xnio.channels.AssembledSslChannel
-
- startHandshake() - Method in interface org.xnio.channels.SslChannel
-
Start or restart the SSL/TLS handshake.
- startHandshake() - Method in class org.xnio.ssl.SslConnection
-
Start or restart the SSL/TLS handshake.
- StreamChannel - Interface in org.xnio.channels
-
A stream channel.
- streamClosed() - Method in interface org.xnio._private.Messages
-
- StreamConnection - Class in org.xnio
-
A connection between peers.
- StreamConnection(XnioIoThread) - Constructor for class org.xnio.StreamConnection
-
Construct a new instance.
- Streams - Class in org.xnio.streams
-
Stream utility class.
- StreamSinkChannel - Interface in org.xnio.channels
-
A stream sink channel.
- StreamSinkChannelWrappingConduit - Class in org.xnio.conduits
-
A conduit which wraps a channel, for compatibility.
- StreamSinkChannelWrappingConduit(StreamSinkChannel) - Constructor for class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
Construct a new instance.
- StreamSinkConduit - Interface in org.xnio.conduits
-
A sink (writable) conduit for byte streams.
- StreamSourceChannel - Interface in org.xnio.channels
-
A stream source channel.
- StreamSourceChannelWrappingConduit - Class in org.xnio.conduits
-
A conduit which wraps a channel, for compatibility.
- StreamSourceChannelWrappingConduit(StreamSourceChannel) - Constructor for class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
Construct a new instance.
- StreamSourceConduit - Interface in org.xnio.conduits
-
- substring(int) - Method in class org.xnio.ByteString
-
Get the substring of this string starting at the given offset.
- substring(int, int) - Method in class org.xnio.ByteString
-
Get the substring of this string starting at the given offset.
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledMessageChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.AssembledStreamChannel
-
- supportsOption(Option<?>) - Method in interface org.xnio.channels.Configurable
-
Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.PushBackStreamChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Determine whether an option is supported on this channel.
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- supportsOption(Option<?>) - Method in class org.xnio.Connection
-
- supportsOption(Option<?>) - Method in class org.xnio.XnioWorker
-
- SuspendableAcceptChannel - Interface in org.xnio.channels
-
A suspendable accept channel.
- SuspendableChannel - Interface in org.xnio.channels
-
A suspendable bidirectional channel.
- SuspendableReadChannel - Interface in org.xnio.channels
-
A suspendable readable channel.
- SuspendableWriteChannel - Interface in org.xnio.channels
-
A suspendable writable channel.
- suspendAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.channels.AssembledMessageChannel
-
- suspendReads() - Method in class org.xnio.channels.AssembledStreamChannel
-
- suspendReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- suspendReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- suspendReads() - Method in class org.xnio.channels.PushBackStreamChannel
-
- suspendReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- suspendReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Suspend further read notifications on this channel.
- suspendReads() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- suspendReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- suspendReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- suspendReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- suspendReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- suspendReads() - Method in interface org.xnio.conduits.SourceConduit
-
- suspendReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- suspendWrites() - Method in class org.xnio.channels.AssembledMessageChannel
-
- suspendWrites() - Method in class org.xnio.channels.AssembledStreamChannel
-
- suspendWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- suspendWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- suspendWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- suspendWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
Suspend further write notifications on this channel.
- suspendWrites() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Suspend further write notifications on this channel.
- suspendWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- suspendWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- suspendWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- suspendWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- suspendWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- suspendWrites() - Method in interface org.xnio.conduits.SinkConduit
-
- suspendWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- 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(ByteBuffer[], int, int) - Static method in class org.xnio.Buffers
-
Take all of the remaining bytes from the buffers and return them in an array.
- take(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.
- terminated() - Method in class org.xnio.conduits.ReadReadyHandler.ChannelListenerHandler
-
- terminated() - Method in class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
-
- terminated() - Method in interface org.xnio.conduits.TerminateHandler
-
Indicate that a previous shutdown request has successfully resulted in termination.
- terminated() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
-
- TerminateHandler - Interface in org.xnio.conduits
-
The base ready handler type, which can forward termination requests as well as notifications of termination
completion.
- TerminateHandler.ChannelListenerHandler<C extends Channel & CloseListenerSettable<C>> - Class in org.xnio.conduits
-
A terminate handler which calls a channel listener on termination notification.
- TerminateHandler.ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.TerminateHandler.ChannelListenerHandler
-
Construct a new instance.
- TerminateHandler.ReadyTask - Class in org.xnio.conduits
-
- TerminateHandler.ReadyTask(TerminateHandler) - Constructor for class org.xnio.conduits.TerminateHandler.ReadyTask
-
Construct a new instance.
- terminateReads() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- terminateReads() - Method in class org.xnio.conduits.BufferedStreamSourceConduit
-
- terminateReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- terminateReads() - Method in class org.xnio.conduits.FramingMessageSourceConduit
-
- terminateReads() - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- terminateReads() - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- terminateReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that no more data will be read from this conduit.
- terminateReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- terminateWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- terminateWrites() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- terminateWrites() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- terminateWrites() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- terminateWrites() - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- terminateWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- terminateWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Signal that no more write data is forthcoming.
- terminateWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- thisTyped() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
Get this channel, cast to the implemented channel type.
- thread - Variable in class org.xnio.Connection
-
- THREAD_DAEMON - Static variable in class org.xnio.Options
-
Specify whether worker threads should be daemon threads.
- THREAD_PRIORITY - Static variable in class org.xnio.Options
-
The thread priority for newly created worker threads.
- toArray() - Method in class org.xnio.Sequence
-
Get a copy of the values array.
- toString(String) - Method in class org.xnio.ByteString
-
Convert this byte string to a standard string.
- toString() - Method in class org.xnio.ChannelListener.SimpleSetter
-
- 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 class org.xnio.Property
-
Get the
String
representation of this property.
- toString() - Method in enum org.xnio.sasl.SaslQop
-
Get the human-readable string representation of this SASL QOP value.
- toString() - Method in 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(StreamSourceConduit, long, ByteBuffer, WritableByteChannel) - Static method in class org.xnio.conduits.Conduits
-
Platform-independent channel-to-channel transfer method.
- transfer(ReadableByteChannel, long, ByteBuffer, StreamSinkConduit) - Static method in class org.xnio.conduits.Conduits
-
Platform-independent channel-to-channel transfer method.
- transfer(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.
- transferBlocking(StreamSinkChannel, StreamSourceChannel, ByteBuffer, long) - Static method in class org.xnio.channels.Channels
-
Transfer bytes between two channels efficiently, blocking if necessary.
- transferFrom(ReadableByteChannel, long, long) - Method in class java.nio.channels.FileChannel
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.AssembledStreamChannel
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- transferFrom(FileChannel, long, long) - Method in interface org.xnio.channels.StreamSinkChannel
-
Transfer bytes into this channel from the given file.
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in interface org.xnio.channels.StreamSinkChannel
-
Transfers bytes from the given channel source.
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- transferFrom(FileChannel, long, long) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- transferFrom(FileChannel, long, long) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Transfer bytes into this conduit from the given file.
- transferFrom(StreamSourceChannel, long, ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Transfers bytes from the given channel source.
- transferTo(long, long, WritableByteChannel) - Method in class java.nio.channels.FileChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.AssembledStreamChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.AssembledStreamChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.PushBackStreamChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.PushBackStreamChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- transferTo(long, long, FileChannel) - Method in interface org.xnio.channels.StreamSourceChannel
-
Transfers bytes into the given file from this channel.
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in interface org.xnio.channels.StreamSourceChannel
-
Transfers bytes into the given channel target.
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.AbstractStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.BufferedStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.FixedLengthStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.InflatingStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.MessageStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.MessageStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.PushBackStreamSourceConduit
-
- transferTo(long, long, FileChannel) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- transferTo(long, long, FileChannel) - Method in interface org.xnio.conduits.StreamSourceConduit
-
Transfers bytes into the given file from this channel.
- transferTo(long, ByteBuffer, StreamSinkChannel) - Method in interface org.xnio.conduits.StreamSourceConduit
-
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 Result
s 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.
- truncate(long) - Method in class java.nio.channels.FileChannel
-
- truncateWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- truncateWrites() - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- truncateWrites() - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- truncateWrites() - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- truncateWrites() - Method in class org.xnio.conduits.FramingMessageSinkConduit
-
- truncateWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- truncateWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Terminate writes and discard any outstanding write data.
- truncateWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- tryAddReadRequiresExternal() - Method in class org.xnio.channels.TranslatingSuspendableChannel
-
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.
- tryLock(long, long, boolean) - Method in class java.nio.channels.FileChannel
-
- tryLock() - Method in class java.nio.channels.FileChannel
-
- 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.
- txMsgTooLarge() - Method in interface org.xnio._private.Messages
-
- 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.
- wakeupAccepts() - Method in interface org.xnio.channels.SuspendableAcceptChannel
-
- wakeupReads() - Method in class org.xnio.channels.AssembledMessageChannel
-
- wakeupReads() - Method in class org.xnio.channels.AssembledStreamChannel
-
- wakeupReads() - Method in class org.xnio.channels.EmptyStreamSourceChannel
-
- wakeupReads() - Method in class org.xnio.channels.FixedLengthStreamSourceChannel
-
- wakeupReads() - Method in class org.xnio.channels.PushBackStreamChannel
-
- wakeupReads() - Method in class org.xnio.channels.SplitStreamSourceChannel
-
- wakeupReads() - Method in interface org.xnio.channels.SuspendableReadChannel
-
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.
- wakeupReads() - Method in class org.xnio.conduits.AbstractSourceConduit
-
- wakeupReads() - Method in class org.xnio.conduits.BlockingStreamSourceConduit
-
- wakeupReads() - Method in class org.xnio.conduits.ConduitReadableMessageChannel
-
- wakeupReads() - Method in class org.xnio.conduits.ConduitStreamSourceChannel
-
- wakeupReads() - Method in class org.xnio.conduits.EmptyStreamSourceConduit
-
- wakeupReads() - Method in interface org.xnio.conduits.SourceConduit
-
Indicate that the conduit's
ReadReadyHandler
should be invoked immediately, and then again as soon
as data can be read without blocking.
- wakeupReads() - Method in class org.xnio.conduits.StreamSourceChannelWrappingConduit
-
- wakeupWrites() - Method in class org.xnio.channels.AssembledMessageChannel
-
- wakeupWrites() - Method in class org.xnio.channels.AssembledStreamChannel
-
- wakeupWrites() - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- wakeupWrites() - Method in class org.xnio.channels.NullStreamSinkChannel
-
- wakeupWrites() - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- wakeupWrites() - Method in interface org.xnio.channels.SuspendableWriteChannel
-
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.
- wakeupWrites() - Method in class org.xnio.conduits.AbstractSinkConduit
-
- wakeupWrites() - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- wakeupWrites() - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- wakeupWrites() - Method in class org.xnio.conduits.ConduitWritableMessageChannel
-
- wakeupWrites() - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- wakeupWrites() - Method in interface org.xnio.conduits.SinkConduit
-
Indicate that the conduit's
WriteReadyHandler
should be invoked immediately, and then again as soon
as data can be written without blocking.
- wakeupWrites() - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- WATCHER_POLL_INTERVAL - Static variable in class org.xnio.Options
-
The poll interval for poll based file system watchers.
- watchPath(File, FileChangeCallback) - Method in interface org.xnio.FileSystemWatcher
-
Watch the given path recursively, and invoke the callback when a change is made.
- WORKER_ACCEPT_THREADS - Static variable in class org.xnio.Options
-
Deprecated.
- WORKER_ESTABLISH_WRITING - Static variable in class org.xnio.Options
-
Specify whether a server, acceptor, or connector should be attached to write threads.
- WORKER_IO_THREADS - Static variable in class org.xnio.Options
-
Specify the number of I/O threads to create for the worker.
- WORKER_NAME - Static variable in class org.xnio.Options
-
The name to use for a newly created worker.
- WORKER_READ_THREADS - Static variable in class org.xnio.Options
-
- 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
-
- wrap(SaslClient, ByteBuffer, ByteBuffer) - Static method in class org.xnio.sasl.SaslUtils
-
Wrap a message.
- wrap(SaslClient, 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(SaslServer, 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) - 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) - Method in class java.nio.channels.FileChannel
-
- write(ByteBuffer[], int, int) - Method in class java.nio.channels.FileChannel
-
- write(ByteBuffer[]) - Method in class java.nio.channels.FileChannel
-
- write(ByteBuffer, long) - Method in class java.nio.channels.FileChannel
-
- write(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
-
- write(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.BlockingByteChannel
-
Perform a blocking, gathering write operation.
- write(ByteBuffer[]) - 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(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- write(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- write(ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- write(ByteBuffer[]) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- write(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- write(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- write(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- write(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- write(ByteBuffer) - Method in class org.xnio.conduits.ConduitWritableByteChannel
-
- write(ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- write(ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- write(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- write(ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes a sequence of bytes to this conduit from the given buffer.
- write(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSinkConduit
-
Writes a sequence of bytes to this conduit from the given buffers.
- 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.
- writeClosed() - Method in class org.xnio.Connection
-
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.AssembledStreamChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.AssembledStreamChannel
-
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.AssembledStreamChannel
-
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.FixedLengthStreamSinkChannel
-
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.NullStreamSinkChannel
-
- writeFinal(ByteBuffer) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- writeFinal(ByteBuffer[]) - Method in class org.xnio.channels.SplitStreamSinkChannel
-
- writeFinal(ByteBuffer) - Method in interface org.xnio.channels.StreamSinkChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in interface org.xnio.channels.StreamSinkChannel
-
- writeFinal(ByteBuffer[]) - Method in interface org.xnio.channels.StreamSinkChannel
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.AbstractStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BlockingStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.BufferedStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- writeFinal(ByteBuffer[]) - Method in class org.xnio.conduits.ConduitStreamSinkChannel
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.DeflatingStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.FixedLengthStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.MessageStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.NullStreamSinkConduit
-
- writeFinal(ByteBuffer) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in class org.xnio.conduits.StreamSinkChannelWrappingConduit
-
- writeFinal(ByteBuffer) - Method in interface org.xnio.conduits.StreamSinkConduit
-
- writeFinal(ByteBuffer[], int, int) - Method in interface org.xnio.conduits.StreamSinkConduit
-
- writeFinalBasic(StreamSinkChannel, ByteBuffer) - Static method in class org.xnio.channels.Channels
-
Writes out the data in the buffer to the channel.
- writeFinalBasic(StreamSinkChannel, ByteBuffer[], int, int) - Static method in class org.xnio.channels.Channels
-
Writes out the data in the buffer to the channel.
- writeFinalBasic(StreamSinkConduit, ByteBuffer) - Static method in class org.xnio.conduits.Conduits
-
Writes the buffer to the conduit, and terminates writes if all the data is written
- writeFinalBasic(StreamSinkConduit, ByteBuffer[], int, int) - Static method in class org.xnio.conduits.Conduits
-
Writes the buffer to the conduit, and terminates writes if all the data is written
- WriteListenerSettable<C extends Channel> - Interface in org.xnio.channels
-
An object which supports directly setting the write listener may implement this interface.
- WriteListenerSettable.Setter<C extends Channel> - Class in org.xnio.channels
-
A channel listener setter implementation which delegates to the appropriate setter method.
- WriteListenerSettable.Setter(WriteListenerSettable<C>) - Constructor for class org.xnio.channels.WriteListenerSettable.Setter
-
Construct a new instance.
- writeReady() - Method in class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
-
- writeReady() - Method in interface org.xnio.conduits.WriteReadyHandler
-
Signify that writes are ready.
- WriteReadyHandler - Interface in org.xnio.conduits
-
A conduit write-ready handler.
- WriteReadyHandler.ChannelListenerHandler<C extends SuspendableWriteChannel & WriteListenerSettable<C> & CloseListenerSettable<C>> - Class in org.xnio.conduits
-
A write ready handler which calls channel listener(s).
- WriteReadyHandler.ChannelListenerHandler(C) - Constructor for class org.xnio.conduits.WriteReadyHandler.ChannelListenerHandler
-
Construct a new instance.
- WriteReadyHandler.ReadyTask - Class in org.xnio.conduits
-
- WriteReadyHandler.ReadyTask(WriteReadyHandler) - Constructor for class org.xnio.conduits.WriteReadyHandler.ReadyTask
-
Construct a new instance.
- 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.
- writeShutDown() - Method in interface org.xnio._private.Messages
-
- writeShutdownChannelListener(ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A write shutdown channel listener.
- writeSuspendingChannelListener(ChannelListener<? super T>) - Static method in class org.xnio.ChannelListeners
-
A write-suspending channel listener.
- writeTimeout() - Method in interface org.xnio._private.Messages
-
- 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.
- writingChannelListener(Pooled<ByteBuffer>, ChannelListener<? super T>, ChannelExceptionHandler<? super T>) - Static method in class org.xnio.ChannelListeners
-
A writing channel listener.
- wrongBufferExpansion() - Method in interface org.xnio._private.Messages
-