A B C D E F G H I J K L M N O P Q R S T U V W Z _ 
All Classes All Packages

R

RANDOM - Static variable in class org.glassfish.grizzly.AbstractBindingHandler
 
RangeDecoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
RangeDecoder
RangeDecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
RangeEncoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
RangeEncoder
RangeEncoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
read() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Performs a blocking read.
read() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read() - Method in interface org.glassfish.grizzly.Readable
Method reads data.
read() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
read() - Method in interface org.glassfish.grizzly.streams.Input
 
read() - Method in class org.glassfish.grizzly.streams.StreamInput
 
read() - Method in class org.glassfish.grizzly.utils.BufferInputStream
read(byte[], int, int) - Method in class org.glassfish.grizzly.utils.BufferInputStream
read(CompletionHandler<ReadResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read(CompletionHandler<ReadResult<M, L>>) - Method in interface org.glassfish.grizzly.Readable
 
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Method reads data to the buffer.
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
Method reads data to the message.
read(Connection<L>) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data.
read(Connection<L>) - Method in interface org.glassfish.grizzly.Reader
Method reads data.
read(Connection<L>, Buffer) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection<L>, Buffer) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>, Interceptor<ReadResult>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection, Buffer) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
read(Connection, CompletionHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
read(Connection, CompletionHandler<ReadResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(Connection, CompletionHandler<ReadResult>) - Method in interface org.glassfish.grizzly.Processor
 
read(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
read(UDPNIOConnection, Buffer) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
read(UDPNIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
READ - org.glassfish.grizzly.filterchain.FilterChainContext.Operation
 
READ - org.glassfish.grizzly.IOEvent
Event occurs on a Connection, once it gets available for read.
READ_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
read0(NIOConnection, ReadResult<Buffer, SocketAddress>, Buffer, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
Readable<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to read data from internal source to a Buffer.
readBlock() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
readBoolean() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next boolean in the stream.
readBoolean() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next boolean in the stream.
readBooleanArray(boolean[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with booleans (byte 1=true, 0=false) from the stream.
readBooleanArray(boolean[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with booleans (byte 1=true, 0=false) from the stream.
readBuffer(TCPNIOConnection, Buffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readBufferSize - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default buffer size for read operations
readBufferSize - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
readByte() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next byte in the stream.
readByte() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next byte in the stream.
readByteArray(byte[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with bytes from the stream.
readByteArray(byte[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with bytes from the stream.
readByteArray(byte[], int, int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with bytes from the stream.
readByteArray(byte[], int, int) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with bytes from the stream.
readBytes(Buffer) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill the buffer with data from the stream (that is, copy data from the stream to fill buffer from position to limit).
readBytes(Buffer) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill the buffer with data from the stream (that is, copy data from the stream to fill buffer from position to limit).
readChar() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next character in the stream.
readChar() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next character in the stream.
readCharArray(char[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readCharArray(char[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readCompositeBuffer(TCPNIOConnection, CompositeBuffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readDouble() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next double in the stream.
readDouble() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next double in the stream.
readDoubleArray(double[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readDoubleArray(double[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
Reader<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to read data from Connection to a Buffer.
readFloat() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next float in the stream.
readFloat() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next float in the stream.
readFloatArray(float[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readFloatArray(float[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readFromFileChannel(FileChannel, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Reads data from the FileChannel into the Buffer.
ReadHandler - Interface in org.glassfish.grizzly
This class represents a call-back mechanism that will notify implementations as more input data becomes available to read without blocking.
readInt() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next int in the stream.
readInt() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next int in the stream.
readIntArray(int[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readIntArray(int[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readLong() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next long in the stream.
readLong() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next long in the stream.
readLongArray(long[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readLongArray(long[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorReader
 
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorReader
 
readOnly - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
ReadResult<K,​L> - Class in org.glassfish.grizzly
Result of read operation, returned by Readable.
ReadResult() - Constructor for class org.glassfish.grizzly.ReadResult
 
ReadResult(Connection<L>) - Constructor for class org.glassfish.grizzly.ReadResult
 
ReadResult(Connection<L>, K, L, int) - Constructor for class org.glassfish.grizzly.ReadResult
 
readShort() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next short in the stream.
readShort() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next short in the stream.
readShortArray(short[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readShortArray(short[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readSimpleBuffer(TCPNIOConnection, Buffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readTimeout - Variable in class org.glassfish.grizzly.AbstractTransport
 
readTimeout - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
readTimeoutMillis - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
ready() - Method in interface org.glassfish.grizzly.ShutdownContext
Invoked by called GracefulShutdownListener to notify the graceful termination process that it's safe to terminate the transport.
readyData() - Method in interface org.glassfish.grizzly.InputSource
 
ReadyFutureImpl<R> - Class in org.glassfish.grizzly.impl
Future implementation with the specific unmodifiable result.
reallocate(E, int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Reallocate Buffer to a required size.
reallocate(E, int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
Creates a new Buffer with a set size and assigns it the data that was held in the old one as long as the given size is not smaller than the data held.
reallocate(Buffer, int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Reallocates an existing buffer to at least the specified size.
reallocate(ByteBufferWrapper, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Reallocate Buffer to a required size.
reallocate(HeapBuffer, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Reallocate Buffer to a required size.
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
reallocateByteBuffer(ByteBuffer, int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
reallocateByteBuffer(ByteBuffer, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
reallocateByteBuffer(MemoryManager, ByteBuffer, int) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
reallocateHeapBuffer(HeapBuffer, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
reconfigure(ThreadPoolConfig) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
RecordReadResult<K,​L> - Class in org.glassfish.grizzly.asyncqueue
Read result associated with a AsyncWriteQueueRecord.
RecordReadResult() - Constructor for class org.glassfish.grizzly.asyncqueue.RecordReadResult
 
RecordWriteResult<K,​L> - Class in org.glassfish.grizzly.asyncqueue
Write result associated with a AsyncWriteQueueRecord.
RecordWriteResult() - Constructor for class org.glassfish.grizzly.asyncqueue.RecordWriteResult
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.RecordReadResult
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.RecordWriteResult
 
recycle() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Recycle AttributeHolder
recycle() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Recycle AttributeHolder
recycle() - Method in interface org.glassfish.grizzly.Cacheable
 
recycle() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
recycle() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
recycle() - Method in class org.glassfish.grizzly.Context
Recycle this Context
recycle() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.BufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
recycle() - Method in class org.glassfish.grizzly.ReadResult
 
recycle() - Method in class org.glassfish.grizzly.TransformationResult
Recycle this Context
recycle() - Method in class org.glassfish.grizzly.WriteResult
 
recycle(boolean) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Recycle GrizzlyFuture now.
recycle(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycleMark - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycleTemporaryArtifacts(Selector, SelectionKey) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
recycleTrack - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
reduceLastAllocated(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
Reduces the buffer to the last data allocated
reduceOffsets(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
Reentrant() - Constructor for class org.glassfish.grizzly.Writer.Reentrant
 
register() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
register(Object, Object) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object as child of the passed parent object.
register(Object, Object, String) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object as child of the passed parent object with the specific name.
RegisterAcceptedChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
RegisterAcceptedChannelCompletionHandler(FutureImpl<Connection>) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
registerAtRoot(Object) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object at the root.
registerAtRoot(Object, String) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object at the root with the passed name.
registerChannel(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectableChannel, int) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registerChannel(SelectorRunner, SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannel(SelectorRunner, SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelAsync(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registerChannelAsync(SelectorRunner, SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannelAsync(SelectorRunner, SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelCompletionHandler - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
RegisterChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport.RegisterChannelCompletionHandler
 
RegisterChannelResult - Class in org.glassfish.grizzly.nio
 
RegisterChannelResult(SelectorRunner, SelectionKey, SelectableChannel) - Constructor for class org.glassfish.grizzly.nio.RegisterChannelResult
 
registerKeyInterest(SelectorRunner, SelectionKey, int) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerKeyInterest(SelectorRunner, SelectionKey, int) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
RegisterKeyTask(SelectionKey, int) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
registerServiceChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerServiceChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registrationStackTrace - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
release() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Perform message specific actions to release resources held by the entity backing this WritableMessage.
release() - Method in class org.glassfish.grizzly.Context
Alternative to Context.recycle() that allows cleanup actions to be performed without returning this instance to the cache.
release() - Method in class org.glassfish.grizzly.FileTransfer
Perform message specific actions to release resources held by the entity backing this WritableMessage.
release() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
release() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
release() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
release() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
release() - Method in class org.glassfish.grizzly.utils.Pair
 
release() - Method in interface org.glassfish.grizzly.utils.PoolableObject
 
release(E) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Release Buffer.
release(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
deallocates the data in the buffer
release(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
release(AttributeStorage) - Method in interface org.glassfish.grizzly.Transformer
The Transformer has done its work and can release all associated resource.
release(AttributeStorage) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
release(Buffer) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Release Buffer.
release(ByteBufferWrapper) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Lets JVM Garbage collector to release buffer.
release(HeapBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Release Buffer.
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
releaseByteBuffer(ByteBuffer) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
releaseByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
releaseByteBuffer(MemoryManager, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
releaseHeapBuffer(HeapBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
releaseSpace(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Releases memory space in the queue.
releaseSpaceAndNotify(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Releases memory space in the queue and notifies registered QueueMonitors about the update.
remaining() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
remaining() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Return the number of bytes remaining to be written.
remaining() - Method in interface org.glassfish.grizzly.Buffer
Returns the number of elements between the current position and the limit.
remaining() - Method in class org.glassfish.grizzly.FileTransfer
Return the number of bytes remaining to be written.
remaining() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
remaining() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
remaining() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
remaining() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
Gets the number of elements between the current position and the limit
REMOTELY - org.glassfish.grizzly.CloseType
 
REMOTELY - org.glassfish.grizzly.Connection.CloseType
Deprecated.
 
REMOTELY_CLOSED_REASON - Static variable in class org.glassfish.grizzly.CloseReason
 
remove(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Remove the task from queue.
remove(E) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
remove(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(Object) - Method in class org.glassfish.grizzly.utils.ArraySet
remove(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Remove attribute value, stored on the AttributeHolder.
remove(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Remove attribute value, stored on the AttributeStorage.
remove(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(T[], Object) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Removes the element from the array.
removeAll() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
removeAll() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Removes underlying Buffers, without disposing
removeAll(Object...) - Method in class org.glassfish.grizzly.utils.ArraySet
Remove element(s) from the set.
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
removeAllLifeCycleListeners() - Method in class org.glassfish.grizzly.Context
 
removeAttribute(int) - Method in interface org.glassfish.grizzly.attributes.IndexedAttributeAccessor
Internal method for dynamic attribute support.
removeAttribute(int) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
 
removeAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Remove a name/value object.
removeAttribute(String) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Remove a name/value object.
removeCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Closeable
Remove the CloseListener.
removeCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Connection
removeCloseListener(CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
removeCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
removeCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
removeCompletionListener(FilterChainContext.CompletionListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
removeCopyListener(FilterChainContext.CopyListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
removeHandshakeListener(SSLBaseFilter.HandshakeListener) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
removeLifeCycleListener(IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.Context
 
removeMonitoringProbe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Remove the ConnectionProbe.
removeProbes(E...) - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Remove the monitoring probes.
removeProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Remove the monitoring probes.
removeRightBuffers(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
removeTimeout(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
renegotiate(SSLConnectionContext, FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
Performs an SSL renegotiation.
rep0 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep1 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep2 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep3 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
replace(Buffer, Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
replace(Buffer, Buffer) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Replace one internal Buffer with another one.
REREGISTER - org.glassfish.grizzly.ProcessorResult.Status
 
RERUN - org.glassfish.grizzly.ProcessorResult.Status
 
RerunFilterAction - Class in org.glassfish.grizzly.filterchain
This NextAction instructs the FilterChain to rerun the same Filter again.
reserveSpace(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Reserves memory space in the queue.
reset() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
reset() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
reset() - Method in interface org.glassfish.grizzly.Buffer
Resets this buffer's position to the previously-marked position.
reset() - Method in class org.glassfish.grizzly.Context
If implementation uses ObjectPool to store and reuse Context instances - this method will be called before Context will be offered to pool.
reset() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Release the context associated resources.
reset() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
reset() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
reset() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
reset() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
reset() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
reset() - Method in class org.glassfish.grizzly.ReadResult
 
reset() - Method in class org.glassfish.grizzly.TransformationResult
If implementation uses ObjectPool to store and reuse TransformationResult instances - this method will be called before TransformationResult will be offered to pool.
reset() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
reset() - Method in class org.glassfish.grizzly.WriteResult
 
reset(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
Resets the Buffer to empty values and empties the pool
RESET - Static variable in interface org.glassfish.grizzly.Interceptor
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
restore() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
result - Variable in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
result - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
result(R) - Method in interface org.glassfish.grizzly.impl.FutureImpl
Set the result value and notify about operation completion.
result(R) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
result(R) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Set the result value and notify about operation completion.
result(R) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Set the result value and notify about operation completion.
Result - Interface in org.glassfish.grizzly
Common I/O result interface.
ResultAware<E> - Interface in org.glassfish.grizzly.utils
 
resume() - Method in class org.glassfish.grizzly.Context
Notify Context its processing will be resumed in the current thread.
resume() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume processing of the current task
resume() - Method in class org.glassfish.grizzly.nio.NIOTransport
Resume UDPNIOTransport, which has been paused before using NIOTransport.pause().
resume() - Method in interface org.glassfish.grizzly.Transport
Resumes the transport after a pause
resume(Context) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
resume(NextAction) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume the current FilterChain task processing by completing the current Filter (the Filter, which suspended the processing) with the passed NextAction.
resumeNext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume processing of the current task starting from the Filter, which follows the Filter, which suspend the processing.
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
retrieve(Properties) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
retryNow() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Instructs Grizzly to try to resend the message right now.
retryWhenPossible() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Instructs Grizzly to send this message once some resources get released.
reuseAddress - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
reverseDecode(LZMADecoder.LZMAInputState, short[], int, RangeDecoder, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseDecode(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseEncode(short[], int, RangeEncoder, int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseEncode(RangeEncoder, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseGetPrice(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseGetPrice(short[], int, int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
rewind() - Method in interface org.glassfish.grizzly.Buffer
Rewinds this buffer.
rewind() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
rewind() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
rewind() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
RoundRobinConnectionDistributor - Class in org.glassfish.grizzly.nio
RoundRobin NIOConnectionDistributor implementation, which allocates one SelectorRunner for OP_ACCEPT events and other event will be assign to a next SelectorRunner from the array.
RoundRobinConnectionDistributor(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
RoundRobinConnectionDistributor(NIOTransport, boolean) - Constructor for class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
RoundRobinConnectionDistributor(NIOTransport, boolean, boolean) - Constructor for class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
Constructs RoundRobinConnectionDistributor with the given configuration.
run() - Method in interface org.glassfish.grizzly.nio.SelectorHandler.Task
 
run() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
run() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeregisterChannelOperation
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterChannelOperation
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RunnableTask
 
run(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandlerTask
 
running - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
RUNNING - org.glassfish.grizzly.filterchain.FilterChainContext.State
 
A B C D E F G H I J K L M N O P Q R S T U V W Z _ 
All Classes All Packages