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

A

AbstractBufferArray<E> - Class in org.glassfish.grizzly.memory
 
AbstractBufferArray(Class<E>) - Constructor for class org.glassfish.grizzly.memory.AbstractBufferArray
 
AbstractCodecFilter<K,L> - Class in org.glassfish.grizzly.filterchain
 
AbstractCodecFilter(Transformer<K, L>, Transformer<L, K>) - Constructor for class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
AbstractFilterChain - Class in org.glassfish.grizzly.filterchain
Abstract FilterChain implementation, which redirects Processor.process(org.glassfish.grizzly.Context) call to the FilterChain.execute(org.glassfish.grizzly.filterchain.FilterChainContext)
AbstractFilterChain() - Constructor for class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
AbstractIOStrategy - Class in org.glassfish.grizzly.strategies
 
AbstractIOStrategy() - Constructor for class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
AbstractJmxMonitoringConfig<E> - Class in org.glassfish.grizzly.monitoring.jmx
The abstract class, which represents the JMX aware configuration object.
AbstractJmxMonitoringConfig(Class<E>) - Constructor for class org.glassfish.grizzly.monitoring.jmx.AbstractJmxMonitoringConfig
 
AbstractMemoryManager<E extends Buffer> - Class in org.glassfish.grizzly.memory
A MemoryManager abstraction to provide utilities that may be useful across different MemoryManager implementations.
AbstractMemoryManager() - Constructor for class org.glassfish.grizzly.memory.AbstractMemoryManager
Creates a new AbstractMemoryManager using a max buffer size of 65536.
AbstractMemoryManager(int) - Constructor for class org.glassfish.grizzly.memory.AbstractMemoryManager
Creates a new AbstractMemoryManager using the specified buffer size.
AbstractMemoryManager.TrimAware - Interface in org.glassfish.grizzly.memory
This is a marker interface indicating a particular Buffer implementation can be trimmed.
AbstractNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio
The AsyncQueueReader implementation, based on the Java NIO
AbstractNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
AbstractNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio
The AsyncQueueWriter implementation, based on the Java NIO
AbstractNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
AbstractNIOConnectionDistributor - Class in org.glassfish.grizzly.nio
 
AbstractNIOConnectionDistributor(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
AbstractReader<L> - Class in org.glassfish.grizzly
Abstract class, which provides transitive dependencies for overloaded Reader methods.
AbstractReader() - Constructor for class org.glassfish.grizzly.AbstractReader
 
AbstractSocketConnectorHandler - Class in org.glassfish.grizzly
Abstract class simplifies the implementation of SocketConnectorHandler interface by pre-implementing some of its methods.
AbstractSocketConnectorHandler(Transport) - Constructor for class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
AbstractSocketConnectorHandler.Builder<E extends AbstractSocketConnectorHandler.Builder> - Class in org.glassfish.grizzly
Builder
AbstractSocketConnectorHandler.Builder(AbstractSocketConnectorHandler) - Constructor for class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
AbstractStreamReader - Class in org.glassfish.grizzly.streams
Each method reads data from the current ByteBuffer.
AbstractStreamReader(Connection, Input) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamReader
Create a new ByteBufferReader.
AbstractStreamWriter - Class in org.glassfish.grizzly.streams
Write the primitive Java type to the current ByteBuffer.
AbstractStreamWriter(Connection, Output) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamWriter
Create a new ByteBufferWriter.
AbstractStreamWriter.DisposeBufferCompletionHandler - Class in org.glassfish.grizzly.streams
 
AbstractStreamWriter.DisposeBufferCompletionHandler(Buffer) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
AbstractThreadPool - Class in org.glassfish.grizzly.threadpool
Abstract ExecutorService implementation.
AbstractThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
AbstractThreadPool.Worker - Class in org.glassfish.grizzly.threadpool
 
AbstractThreadPool.Worker() - Constructor for class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
AbstractTransformer<K,L> - Class in org.glassfish.grizzly
 
AbstractTransformer() - Constructor for class org.glassfish.grizzly.AbstractTransformer
 
AbstractTransformer.LastResultAwareState<K,L> - Class in org.glassfish.grizzly
 
AbstractTransformer.LastResultAwareState() - Constructor for class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
AbstractTransport - Class in org.glassfish.grizzly
Abstract Transport.
AbstractTransport(String) - Constructor for class org.glassfish.grizzly.AbstractTransport
 
AbstractWriter<L> - Class in org.glassfish.grizzly
Abstract class, which provides transitive dependencies for overloaded Writer methods.
AbstractWriter() - Constructor for class org.glassfish.grizzly.AbstractWriter
 
accept() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Accept a Connection.
accept() - Method in interface org.glassfish.grizzly.SocketAcceptor
Accept a Connection
acceptAsync() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Asynchronously accept a Connection
acquireBuffer(Connection) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
ACTIVE_ATTRIBUTE_NAME - Static variable in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible for tracking Connection activity and closing Connection ones it becomes idle for certain amount of time.
ActivityCheckFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter(DelayedExecutor, long, TimeUnit, ActivityCheckFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter(DelayedExecutor, DelayedExecutor.Worker<Connection>, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter.TimeoutHandler - Interface in org.glassfish.grizzly.utils
 
adapt(Integer) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.HandshakeCompletionHandler
 
adapt(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
adapt(K) - Method in interface org.glassfish.grizzly.utils.GenericAdapter
 
add(ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
add(int, ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
add(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(E, int, int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(ArraySet<T>) - Method in class org.glassfish.grizzly.utils.ArraySet
Add all the elements from the source ArraySet.
add(T) - Method in class org.glassfish.grizzly.utils.ArraySet
add(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
add(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
addAll(Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(int, Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(int, Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(int, List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(int, Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(T...) - Method in class org.glassfish.grizzly.utils.ArraySet
Add the element(s) to the set.
addAll(Collection<? extends T>) - Method in class org.glassfish.grizzly.utils.ArraySet
addCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCompletionListener(FilterChainContext.CompletionListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Add the FilterChainContext.CompletionListener, which will be notified, when this FilterChainContext processing will be completed.
addCopyListener(FilterChainContext.CopyListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Add the FilterChainContext.CopyListener, which will be notified, right after this FilterChainContext.copy() is called.
addFirst(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addLast(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addMonitoringProbe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Add the ConnectionProbe, which will be notified about Connection life-cycle events.
addProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Add the monitoring probes, which will be notified about object's lifecycle events.
addProbes(E...) - Method in class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
Add the monitoring probes, which will be notified about object's lifecycle events.
addRecord(Connection, Buffer, CompletionHandler, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
addRecord(Connection, Buffer, CompletionHandler, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
addUnique(T[], T) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Add unique element to the array.
addUnique(T[], T, boolean) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Add unique element to the array.
afterExecute(AbstractThreadPool.Worker, Thread, Runnable, Throwable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method invoked upon completion of execution of the given Runnable.
aggregate(TaskQueue<AsyncWriteQueueRecord>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Aggregates records in a queue to be written as one chunk.
aggregate(TaskQueue<AsyncWriteQueueRecord>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
Aggregates records in a queue to be written as one chunk.
allocate(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocated Buffer of the required size.
allocate(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Allocated Buffer of the required size.
allocate(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Allocated Buffer of the required size.
allocate(int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocated Buffer at least of the provided size.
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Allocated Buffer at least of the provided size.
allocateAtLeast(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Allocated Buffer at least of the provided size.
allocateByteBuffer(int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
allocateByteBuffer(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocates ByteBuffer of required size.
allocateByteBuffer(MemoryManager, int) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
allocateByteBuffer0(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
allocateByteBufferAtLeast(int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
allocateByteBufferAtLeast(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocates ByteBuffer of required size.
allocateFromPool(ThreadLocalPool, int) - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Allocate a Buffer using the provided ThreadLocalPool.
allocateHeapBuffer(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
allocateHeapBufferAtLeast(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
allocateNewBuffer(MemoryManager, int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
allowBufferDispose() - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose(boolean) - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
append(T) - Method in interface org.glassfish.grizzly.Appendable
 
append(E, E) - Method in interface org.glassfish.grizzly.Appender
 
append(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
append(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
Appendable<T> - Interface in org.glassfish.grizzly
 
appendBuffers(MemoryManager, Buffer, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Append two Buffers.
appendBuffers(MemoryManager, Buffer, Buffer, boolean) - Static method in class org.glassfish.grizzly.memory.Buffers
Append two Buffers.
Appender<E> - Interface in org.glassfish.grizzly
 
array() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
ArraySet<T> - Class in org.glassfish.grizzly.utils
The thread safe set implementation, which uses array to hold its elements.
ArraySet(Class<T>) - Constructor for class org.glassfish.grizzly.utils.ArraySet
 
ArraySet(Class<T>, boolean) - Constructor for class org.glassfish.grizzly.utils.ArraySet
 
ArrayUtils - Class in org.glassfish.grizzly.utils
Set of utility methods to work with Arrays.
ArrayUtils() - Constructor for class org.glassfish.grizzly.utils.ArrayUtils
 
ASCII_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
 
asReadOnlyBuffer() - Method in interface org.glassfish.grizzly.Buffer
Creates a new, read-only Buffer that shares this buffer's content.
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
AsyncQueue - Interface in org.glassfish.grizzly.asyncqueue
Common interface for AsyncQueue processors.
AsyncQueue.AsyncResult - Enum in org.glassfish.grizzly.asyncqueue
 
AsyncQueueEnabledTransport - Interface in org.glassfish.grizzly.asyncqueue
Interface, which Transports should implement if they support AsyncQueues.
AsyncQueueIO<L> - Interface in org.glassfish.grizzly.asyncqueue
Class encapsulates asynchronous queue implementation: AsyncQueueReader, AsyncQueueWriter.
asyncQueueIO - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Transport AsyncQueueIO
AsyncQueueIO.Factory - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueIO.Factory() - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
AsyncQueueIO.ImmutableAsyncQueueIO<L> - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueIO.MutableAsyncQueueIO<L> - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueReader<L> - Interface in org.glassfish.grizzly.asyncqueue
The AsyncQueue, which implements asynchronous read queue.
AsyncQueueRecord<R> - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue element unit
AsyncQueueRecord(Connection, Object, R, CompletionHandler) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
AsyncQueueWriter<L> - Interface in org.glassfish.grizzly.asyncqueue
The AsyncQueue, which implements asynchronous write queue.
AsyncQueueWriter.Reentrant - Class in org.glassfish.grizzly.asyncqueue
Write reentrants counter
AsyncQueueWriter.Reentrant() - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueWriter.Reentrant
 
asyncReadQueue - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
AsyncReadQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue read element unit
asyncWriteQueue - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
AsyncWriteQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue write element unit
AsyncWriteQueueRecord(Connection, WritableMessage, WriteResult, CompletionHandler, Object, PushBackHandler, boolean) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
attachToSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
Attribute<T> - Class in org.glassfish.grizzly.attributes
Class used to define dynamic typed attributes on AttributeHolder instances.
Attribute(AttributeBuilder, String, int, T) - Constructor for class org.glassfish.grizzly.attributes.Attribute
 
Attribute(AttributeBuilder, String, int, NullaryFunction<T>) - Constructor for class org.glassfish.grizzly.attributes.Attribute
 
attributeBuilder - Variable in class org.glassfish.grizzly.AbstractTransformer
 
attributeBuilder - Variable in class org.glassfish.grizzly.AbstractTransport
Transport AttributeBuilder, which will be used to create Attributes
AttributeBuilder - Interface in org.glassfish.grizzly.attributes
AttributeBuilder is responsible for creating and indexing Attributes.
attributeBuilder - Variable in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
attributeBuilder - Variable in class org.glassfish.grizzly.attributes.NamedAttributeHolder
 
AttributeHolder - Interface in org.glassfish.grizzly.attributes
Interface declares common functionality for objects, which have associated Attributes.
attributes - Variable in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
attributes - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
attributesMap - Variable in class org.glassfish.grizzly.attributes.NamedAttributeHolder
 
AttributeStorage - Interface in org.glassfish.grizzly.attributes
AttributeStorage provides access to a AttributeHolder, where application can store Attributes.
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
AUTO_SIZE - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Constant set via AsyncQueueWriter.setMaxPendingBytesPerConnection(int) means the async write queue size will be configured automatically per NIOConnection depending on connections write buffer size.
available() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Return the number of bytes available for get calls.
available() - Method in interface org.glassfish.grizzly.streams.StreamReader
Return the number of bytes available for get calls.
available() - Method in class org.glassfish.grizzly.utils.BufferInputStream
awaitTermination(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
awaitTermination(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 

B

Base - Class in org.glassfish.grizzly.compression.lzma.impl
Base
Base() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Base
 
BaseFilter - Class in org.glassfish.grizzly.filterchain
Provides empty implementation for Filter processing methods.
BaseFilter() - Constructor for class org.glassfish.grizzly.filterchain.BaseFilter
 
beforeExecute(AbstractThreadPool.Worker, Thread, Runnable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method invoked prior to executing the given Runnable in the given thread.
bigEndian - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
binarySearch(int[], int, int, int) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
 
bind(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific port on localhost.
bind(String, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host and port.
bind(String, int, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host and port.
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific SocketAddress.
bind(String, PortRange, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host, and port within a PortRange.
bind(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific port on localhost.
bind(String, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host and port.
bind(String, int, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host and port.
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific SocketAddress.
bind(String, PortRange, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host, and port within a PortRange.
bind(int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific port on localhost.
bind(String, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host and port.
bind(String, int, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host and port.
bind(String, PortRange, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host, and port within a PortRange.
bind(SocketAddress) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific SocketAddress.
BinTree - Class in org.glassfish.grizzly.compression.lzma.impl.lz
BinTree
BinTree() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
BitTreeDecoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
BitTreeDecoder
BitTreeDecoder(int) - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
BitTreeEncoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
BitTreeEncoder
BitTreeEncoder(int) - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
Buffer - Interface in org.glassfish.grizzly
JDK ByteBuffer was taken as base for Grizzly Buffer interface, but Buffer has several extensions: it's possible to prepend some data to a Buffer and release Buffer, when it's not required any more.
BUFFER_OVERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
BUFFER_OVERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
BUFFER_UNDERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
BUFFER_UNDERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
BufferArray - Class in org.glassfish.grizzly.memory
 
BufferedInput - Class in org.glassfish.grizzly.streams
 
BufferedInput() - Constructor for class org.glassfish.grizzly.streams.BufferedInput
 
BufferedOutput - Class in org.glassfish.grizzly.streams
 
BufferedOutput() - Constructor for class org.glassfish.grizzly.streams.BufferedOutput
 
BufferedOutput(int) - Constructor for class org.glassfish.grizzly.streams.BufferedOutput
 
BufferInputStream - Class in org.glassfish.grizzly.utils
InputStream implementation over Grizzly Buffer.
BufferInputStream(Buffer) - Constructor for class org.glassfish.grizzly.utils.BufferInputStream
Create the InputStream over Grizzly Buffer.
BufferInputStream(Buffer, int, int) - Constructor for class org.glassfish.grizzly.utils.BufferInputStream
Create the InputStream over Grizzly Buffer.
BufferOutputStream - Class in org.glassfish.grizzly.utils
OutputStream implementation to write to a Buffer.
BufferOutputStream(MemoryManager) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream without initial Buffer.
BufferOutputStream(MemoryManager, Buffer) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream using passed Buffer as initial.
BufferOutputStream(MemoryManager, Buffer, boolean) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream using passed Buffer as initial.
Buffers - Class in org.glassfish.grizzly.memory
Class has useful methods to simplify the work with Buffers.
Buffers() - Constructor for class org.glassfish.grizzly.memory.Buffers
 
BuffersBuffer - Class in org.glassfish.grizzly.memory
 
BuffersBuffer(MemoryManager, Buffer[], int, boolean) - Constructor for class org.glassfish.grizzly.memory.BuffersBuffer
 
bufferSize - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 
build() - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
build() - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder.StatelessFilterChainBuilder
 
build() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
build() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
build() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
builder - Variable in class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
FilterChainBuilder, responsible for creating FilterChain instances
builder(TCPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
Return the TCPNIOConnectorHandler builder.
builder(UDPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
Return the UDPNIOConnectorHandler builder.
bulk(CompositeBuffer.BulkOperation) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Iterates over Buffer bytes from Buffer.position() to Buffer.limit() and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Iterates over Buffer bytes from position to limit and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Iterates over Buffer bytes from Buffer.position() to Buffer.limit() and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation, int, int) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Iterates over Buffer bytes from position to limit and lets CompositeBuffer.BulkOperation examine/change the buffer content;
byteBuffer - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
byteBuffer2String(ByteBuffer) - Static method in class org.glassfish.grizzly.utils.Utils
 
ByteBufferArray - Class in org.glassfish.grizzly.memory
 
ByteBufferAware - Interface in org.glassfish.grizzly.memory
 
ByteBufferManager - Class in org.glassfish.grizzly.memory
The simple Buffer manager implementation, which works as wrapper above ByteBuffers.
ByteBufferManager() - Constructor for class org.glassfish.grizzly.memory.ByteBufferManager
 
ByteBufferManager(boolean, int, int) - Constructor for class org.glassfish.grizzly.memory.ByteBufferManager
 
ByteBufferManager - Class in org.glassfish.grizzly.memory.jmx
ByteBufferManager JMX object.
ByteBufferManager(ByteBufferManager) - Constructor for class org.glassfish.grizzly.memory.jmx.ByteBufferManager
 
ByteBufferManager.SmallByteBufferWrapper - Class in org.glassfish.grizzly.memory
ByteBufferWrapper implementation, which supports trimming.
ByteBufferWrapper - Class in org.glassfish.grizzly.memory
Buffer implementation, which uses the ByteBuffer underneath.
ByteBufferWrapper() - Constructor for class org.glassfish.grizzly.memory.ByteBufferWrapper
 
ByteBufferWrapper(ByteBuffer) - Constructor for class org.glassfish.grizzly.memory.ByteBufferWrapper
 

C

Cacheable - Interface in org.glassfish.grizzly
 
canBeAggregated() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
cancel() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Instructs Grizzly to cancel this message write and release message associated resources.
cancel(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Do nothing.
cancel(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
cancel(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeregisterChannelOperation
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeRegisterKeyTask
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterChannelOperation
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RunnableTask
 
cancel(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
cancel() - Method in interface org.glassfish.grizzly.nio.SelectorHandlerTask
 
cancelled() - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was cancelled.
cancelled() - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was cancelled.
cancelled() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
cancelled() - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
canWrite(Connection, int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
 
canWrite(Connection, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
cap - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
capacity() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's capacity.
capacity() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
capacity() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
capacity() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
CERTIFICATE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the client certificate chain.
ChainProcessorSelector - Class in org.glassfish.grizzly
ProcessorSelector implementation, which acts like wrapper for chain of ProcessorSelectors.
ChainProcessorSelector() - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
ChainProcessorSelector(ProcessorSelector...) - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
ChainProcessorSelector(List<ProcessorSelector>) - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
changed(E) - Method in interface org.glassfish.grizzly.ChangeListener
 
ChangeListener<E> - Interface in org.glassfish.grizzly
 
channel - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
charset - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
charset - Variable in class org.glassfish.grizzly.utils.StringEncoder
 
Charsets - Class in org.glassfish.grizzly.utils
Charset utility class.
Charsets() - Constructor for class org.glassfish.grizzly.utils.Charsets
 
check() - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
check() - Method in class org.glassfish.grizzly.streams.StreamDecodeCondition
 
check() - Method in class org.glassfish.grizzly.streams.TransformerInput.TransformerCondition
 
check() - Method in interface org.glassfish.grizzly.utils.conditions.Condition
 
checkConnectFailed(Throwable) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called in order to check if failure happened before Connection was reported as connected.
checkDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
checkEmptyRead(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
checkRecycled() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
ChunkingFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible to break the incoming/outgoing data into chunks and pass them down/up by the FilterChain.
ChunkingFilter(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter
Construct a ChunkFilter, which will break incoming/outgoing data into chunks of the specified size.
ChunkingFilter.ChunkingDecoder - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingDecoder(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingDecoder
 
ChunkingFilter.ChunkingEncoder - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingEncoder(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingEncoder
 
ChunkingFilter.ChunkingTransformer - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingTransformer(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
CIPHER_SUITE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the cipher suite.
ciphers - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
A mapping table to determine the number of effective bits in the key when using a cipher suite containing the specified cipher name.
clazz - Variable in class org.glassfish.grizzly.memory.AbstractBufferArray
 
clear() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Clear all the attributes.
clear() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Clear all the attributes.
clear() - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Clear all the attributes.
clear() - Method in interface org.glassfish.grizzly.Buffer
Clears this buffer.
clear() - Method in class org.glassfish.grizzly.ChainProcessorSelector
clear() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
clear() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
clear() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
clear() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
clear() - Method in class org.glassfish.grizzly.utils.ArraySet
Remove all the set elements.
clear() - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
clearProbes() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Removes all the monitoring probes, which are registered on the object.
clearProbes() - Method in class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
Removes all the monitoring probes, which are registered on the object.
clearState(FilterChainContext.Operation, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
clientMode - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Client mode when handshaking.
clone(Connection, E) - Method in interface org.glassfish.grizzly.asyncqueue.MessageCloner
Method will be called by AsyncQueueWriter, when message could not be written directly, and will be added to the queue.
cloneBuffer(Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Clones the source Buffer.
cloneBuffer(Buffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Clones the source Buffer.
close() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Close AsyncQueueProcessor and release associated resources
close() - Method in interface org.glassfish.grizzly.Closeable
 
close(CompletionHandler<E>) - Method in interface org.glassfish.grizzly.Closeable
 
close() - Method in interface org.glassfish.grizzly.Connection
Close the Connection
close(CompletionHandler<Connection>) - Method in interface org.glassfish.grizzly.Connection
Close the Connection
close() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Close AsyncQueueProcessor and release associated resources
close() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Close AsyncQueueProcessor and release associated resources
close() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close(CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
close(CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
close() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Closes the StreamReader and causes all subsequent method calls on this object to throw IllegalStateException.
close() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
close() - Method in interface org.glassfish.grizzly.streams.Input
 
close(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Output
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.streams.StreamInput
 
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
close(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
close0(CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close0(CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Closeable<E extends Closeable> - Interface in org.glassfish.grizzly
General asynchronous closable interface.
closeConnection(Connection) - Method in class org.glassfish.grizzly.AbstractTransport
Close the connection, managed by Transport
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
closeSilently() - Method in interface org.glassfish.grizzly.Connection
Close the Connection silently, no notification required on completion or failure.
closeSilently() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
closeTypeFlag - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
code(LZMADecoder.LZMAInputState, long) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
code(LZMAEncoder.LZMAOutputState, long, long) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
Codec<K,L> - Interface in org.glassfish.grizzly
Codec is able to transform the original message to a custom represantation and vise versa.
CodecFilter<K,L> - Interface in org.glassfish.grizzly.filterchain
 
CODECS_CACHE_SIZE - Static variable in class org.glassfish.grizzly.utils.Charsets
 
codeOneBlock(long[], long[], boolean[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
compact() - Method in interface org.glassfish.grizzly.Buffer
Compacts this buffer  (optional operation).
compact() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
compact() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
compact() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
compareTo(String) - Method in class org.glassfish.grizzly.utils.JdkVersion
 
compareTo(JdkVersion) - Method in class org.glassfish.grizzly.utils.JdkVersion
 
COMPLETE_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
completeAndRecycle() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
completed(E) - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was completed.
completed(E) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was completed.
COMPLETED - Static variable in interface org.glassfish.grizzly.Interceptor
 
completed(RegisterChannelResult) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
completed(RegisterChannelResult) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.RegisterChannelCompletionHandler
 
completed(Object) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
completed(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
completionHandler - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
CompletionHandler<E> - Interface in org.glassfish.grizzly
Interface, which will be used by Grizzly to notify about asynchronous I/O operations status updates.
completionHandler - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
CompletionHandlerAdapter<A,B> - Class in org.glassfish.grizzly.utils
 
CompletionHandlerAdapter(FutureImpl<A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
CompletionHandlerAdapter(FutureImpl<A>, CompletionHandler<A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
CompletionHandlerAdapter(FutureImpl<A>, CompletionHandler<A>, GenericAdapter<B, A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
CompositeBuffer - Class in org.glassfish.grizzly.memory
 
CompositeBuffer() - Constructor for class org.glassfish.grizzly.memory.CompositeBuffer
 
compositeBuffer - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
CompositeBuffer.BulkOperation - Interface in org.glassfish.grizzly.memory
Bulk Buffer operation, responsible for byte-by-byte Buffer processing.
CompositeBuffer.Setter - Interface in org.glassfish.grizzly.memory
Setter.
condition - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
Condition - Interface in org.glassfish.grizzly.utils.conditions
 
config - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
config - Variable in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
configSelectorPool(ThreadPoolConfig) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Configure the SelectorRunner pool's default core and max pool size.
configure(SSLEngine) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Configure passed SSLEngine, using current configurator settings
configureBlocking(boolean) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the Transport mode.
configureBlocking(boolean) - Method in interface org.glassfish.grizzly.Connection
Sets the Connection mode.
configureBlocking(boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
configureBlocking(boolean) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
configureBlocking(boolean) - Method in interface org.glassfish.grizzly.Transport
Sets the Transport mode.
configureNIOConnection(UDPNIOConnection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
configureStandalone(boolean) - Method in interface org.glassfish.grizzly.Connection
 
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
configureStandalone(boolean) - Method in interface org.glassfish.grizzly.Transport
 
connect(String, int) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(E) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(E, CompletionHandler<Connection>) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(E, E) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(E, E, CompletionHandler<Connection>) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connect(String, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connect(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
Creates non-connected UDP Connection.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connect() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates non-connected UDP Connection.
connect(String, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connect(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(String, int) - Method in interface org.glassfish.grizzly.SocketConnectorHandler
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connectCloseSemaphor - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
connection - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
Connection<L> - Interface in org.glassfish.grizzly
Common interface, which represents any kind of connection.
connection - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
Connection.CloseListener - Interface in org.glassfish.grizzly
The listener, which is used to be notified, when Connection gets closed.
Connection.CloseType - Enum in org.glassfish.grizzly
 
connectionMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Connection probes
ConnectionProbe - Interface in org.glassfish.grizzly
Monitoring probe providing callbacks that may be invoked by Grizzly Connection implementations.
ConnectionProbe.Adapter - Class in org.glassfish.grizzly
ConnectionProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
ConnectionProbe.Adapter() - Constructor for class org.glassfish.grizzly.ConnectionProbe.Adapter
 
connectionTimeout - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Default channel connection timeout
connectionTimeoutMillis - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectionTimeoutMillis - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connectorHandler - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
ConnectorHandler<E> - Interface in org.glassfish.grizzly
Client side connector handler API.
connectSync(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectSync(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
contains(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
contains(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
contains(Object) - Method in class org.glassfish.grizzly.utils.ArraySet
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
Context - Class in org.glassfish.grizzly
Object, which is responsible for holding context during I/O event processing.
Context() - Constructor for class org.glassfish.grizzly.Context
 
copy() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
copy() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
copy() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
copy(byte[]) - Static method in class org.glassfish.grizzly.utils.Utils
 
copyBlock(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
corePoolSize - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
CRC - Class in org.glassfish.grizzly.compression.lzma.impl
CRC
CRC() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.CRC
 
create(Connection, Buffer, ReadResult, CompletionHandler, Interceptor<ReadResult>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
create(Connection, WritableMessage, WriteResult, CompletionHandler, Object, PushBackHandler, boolean) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
create(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
create(int, int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
create(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
create(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
create() - Static method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
create() - Static method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
create(Connection) - Static method in class org.glassfish.grizzly.Context
 
create(Connection, Processor, IOEvent, IOEventProcessingHandler) - Static method in class org.glassfish.grizzly.Context
 
create(DefaultFilterChain.FILTER_STATE_TYPE, Object) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FilterStateElement
 
create(DefaultFilterChain.FILTER_STATE_TYPE, Appendable) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FilterStateElement
 
create(DefaultFilterChain.FILTER_STATE_TYPE, E, Appender<E>) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FilterStateElement
 
create(Connection) - Static method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
create() - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct cancelled Future.
create(R) - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct Future with the result.
create(Throwable) - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct failed Future.
create() - Static method in class org.glassfish.grizzly.impl.SafeFutureImpl
Construct SafeFutureImpl.
create() - Static method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Construct Future.
create() - Static method in class org.glassfish.grizzly.memory.BufferArray
 
create() - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
Construct BuffersBuffer.
create(MemoryManager) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create(MemoryManager, Buffer...) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create(MemoryManager, Buffer[], boolean) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create() - Static method in class org.glassfish.grizzly.memory.ByteBufferArray
 
create(NIOTransport) - Static method in class org.glassfish.grizzly.nio.SelectorRunner
 
create(Connection) - Static method in class org.glassfish.grizzly.ReadResult
 
create(Connection, K, L, int) - Static method in class org.glassfish.grizzly.ReadResult
 
create(Connection) - Static method in class org.glassfish.grizzly.WriteResult
 
create(Connection, K, L, int) - Static method in class org.glassfish.grizzly.WriteResult
 
createAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name
createAttribute(String, T) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name and default value
createAttribute(String, NullaryFunction<T>) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name and initializer, which will be called, if Attribute's value is null on a AttributedObject
createAttribute(String) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name
createAttribute(String, T) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name and default value
createAttribute(String, NullaryFunction<T>) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name and initializer, which will be called, if Attribute's value is null on a AttributedObject
createComplete() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createComplete(Object) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createCompletedResult(O, I) - Static method in class org.glassfish.grizzly.TransformationResult
 
createContext(Connection, FilterChainContext.Operation) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
createDefaultIdleDelayedExecutor() - Static method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
createDefaultIdleDelayedExecutor(long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
createDefaultIdleDelayedExecutor() - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
createDefaultIdleDelayedExecutor(long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in interface org.glassfish.grizzly.strategies.WorkerThreadPoolConfigProducer
 
createDelayQueue(DelayedExecutor.Worker<E>, DelayedExecutor.Resolver<E>) - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
createError() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createError(Object) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createErrorResult(int, String) - Static method in class org.glassfish.grizzly.TransformationResult
 
createFlushEvent() - Static method in class org.glassfish.grizzly.filterchain.TransportFilter
 
createFlushEvent(CompletionHandler) - Static method in class org.glassfish.grizzly.filterchain.TransportFilter
 
createHeapBuffer(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
createImmutable(AsyncQueueReader<L>, AsyncQueueWriter<L>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
createIncompletedResult(I) - Static method in class org.glassfish.grizzly.TransformationResult
 
createInstance() - Static method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
createInstance(ThreadPoolConfig) - Static method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.AbstractTransport
Create the Transport JMX managment object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Create the Memory Manager JMX management object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
createJmxManagementObject() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Create the Transport JMX managment object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Create the Transport JMX managment object.
createLeave() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createManagementObject() - Method in interface org.glassfish.grizzly.monitoring.jmx.JmxMonitoringConfig
Create the JmxObject, which represents this object.
createMutable(AsyncQueueReader<L>, AsyncQueueWriter<L>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
createNotRun() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createReadyFuture(R) - Static method in class org.glassfish.grizzly.utils.Futures
Create a Future, which has a preset result.
createReadyFuture(Throwable) - Static method in class org.glassfish.grizzly.utils.Futures
Create a Future, which has a preset failure.
createRecord(Connection, WritableMessage, WriteResult<WritableMessage, SocketAddress>, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, SocketAddress, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
createReregister(Context) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createRerun(Context) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createSafeFuture() - Static method in class org.glassfish.grizzly.utils.Futures
Returns thread-safe FutureImpl implementation.
createSmallBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
createSSLContext() - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
createSSLEngine() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create and configure SSLEngine, basing on current settings.
createStateObject() - Method in class org.glassfish.grizzly.AbstractTransformer
 
createStateObject() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
createStateObject() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
createStateObject() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
createStateObject() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
createTaskQueue(TaskQueue.MutableMaxQueueSize) - Static method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
createTerminate() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createThreadLocalPool() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
createThreadLocalPool() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
createThreadLocalPool() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPoolProvider
 
createUnsafeFuture() - Static method in class org.glassfish.grizzly.utils.Futures
Returns non thread-safe FutureImpl implementation.
currentResult - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 

D

DataStructures - Class in org.glassfish.grizzly.utils
 
DataStructures() - Constructor for class org.glassfish.grizzly.utils.DataStructures
 
DEBUG_MODE - Static variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
DEBUG_MODE - Static variable in class org.glassfish.grizzly.memory.HeapBuffer
 
DebugPoint - Class in org.glassfish.grizzly.utils
Utility class, which may stores the current execution position to help tracking threading issues.
DebugPoint(Exception, String) - Constructor for class org.glassfish.grizzly.utils.DebugPoint
 
decAndGet() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueWriter.Reentrant
 
decInitialized - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
decode(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
decode(Transformer<Stream, E>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>, CompletionHandler<E>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>, CompletionHandler<E>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Read and decode data from the StreamReader
decodeBit(LZMADecoder.LZMAInputState, short[], int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
decodeDirectBits(LZMADecoder.LZMAInputState, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
decodeNormal(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
Decoder - Class in org.glassfish.grizzly.compression.lzma.impl
RangeDecoder
Decoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
Decoder.LiteralDecoder - Class in org.glassfish.grizzly.compression.lzma.impl
 
Decoder.LiteralDecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
Decoder.LiteralDecoder.Decoder2 - Class in org.glassfish.grizzly.compression.lzma.impl
 
Decoder.LiteralDecoder.Decoder2() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
Decoder.State - Enum in org.glassfish.grizzly.compression.lzma.impl
 
decoder2 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
decodeWithMatchByte(LZMADecoder.LZMAInputState, RangeDecoder, byte) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
DEFAULT - Static variable in interface org.glassfish.grizzly.Interceptor
 
DEFAULT_ATTRIBUTE_BUILDER - Static variable in interface org.glassfish.grizzly.attributes.AttributeBuilder
The default AttributeBuilder implementation used by all created builder instances.
DEFAULT_ATTRIBUTE_BUILDER - Static variable in class org.glassfish.grizzly.Grizzly
 
DEFAULT_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
DEFAULT_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
DEFAULT_CHARACTER_ENCODING - Static variable in class org.glassfish.grizzly.utils.Charsets
The default character encoding of this Java virtual machine.
DEFAULT_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
Returns the default charset of this Java virtual machine.
DEFAULT_CONFIG - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Default SSL configuration.
DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
DEFAULT_IDLE_THREAD_KEEPALIVE_TIMEOUT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_MAX_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
The maximum size of the memory pool that is to be maintained by either the MemoryManager itself or any ThreadLocalPools.
DEFAULT_MAX_TASKS_QUEUED - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_MAX_THREAD_COUNT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_MEMORY_MANAGER - Static variable in interface org.glassfish.grizzly.memory.MemoryManager
The default MemoryManager implementation used by all created builder instances.
DEFAULT_MIN_THREAD_COUNT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_READ_BUFFER_SIZE - Static variable in interface org.glassfish.grizzly.Transport
The default read buffer size.
DEFAULT_SELECTION_KEY_HANDLER - Static variable in interface org.glassfish.grizzly.nio.SelectionKeyHandler
The default SelectionKeyHandler used by all created builder instances.
DEFAULT_SELECTOR_HANDLER - Static variable in interface org.glassfish.grizzly.nio.SelectorHandler
The default SelectorHandler used by all created builder instances.
DEFAULT_SELECTORS_COUNT - Static variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
DEFAULT_SMALL_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.memory.ByteBufferManager
TODO: Document
DefaultAttributeBuilder - Class in org.glassfish.grizzly.attributes
Default AttributeBuilder implementation.
DefaultAttributeBuilder() - Constructor for class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
defaultBufferSize - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
defaultBufferSize - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
defaultConfig() - Static method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
defaultEndIdx(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
DefaultFilterChain - Class in org.glassfish.grizzly.filterchain
Default FilterChain implementation
DefaultFilterChain() - Constructor for class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
DefaultFilterChain(Collection<Filter>) - Constructor for class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
DefaultFilterChain.FILTER_STATE_TYPE - Enum in org.glassfish.grizzly.filterchain
 
DefaultFilterChain.FiltersState - Class in org.glassfish.grizzly.filterchain
 
DefaultFilterChain.FiltersState(int) - Constructor for class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
DefaultFilterChain.FilterStateElement - Class in org.glassfish.grizzly.filterchain
 
DefaultProcessorSelector - Class in org.glassfish.grizzly
Default ProcessorSelector implementation, which uses Connection's Processor preferences.
DefaultProcessorSelector(Transport) - Constructor for class org.glassfish.grizzly.DefaultProcessorSelector
 
DefaultSelectionKeyHandler - Class in org.glassfish.grizzly.nio
 
DefaultSelectionKeyHandler() - Constructor for class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
DefaultSelectorHandler - Class in org.glassfish.grizzly.nio
Default implementation of NIO SelectorHandler
DefaultSelectorHandler() - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
DefaultSelectorHandler(long, TimeUnit) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
DefaultSelectorHandler.DeregisterChannelOperation - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.DeRegisterKeyTask - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.DeRegisterKeyTask(SelectionKey, int) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeRegisterKeyTask
 
DefaultSelectorHandler.RegisterChannelOperation - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.RegisterKeyTask - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.RegisterKeyTask(SelectionKey, int) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
DefaultSelectorHandler.RunnableTask - Class in org.glassfish.grizzly.nio
 
defaultStartIdx(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
DefaultStreamReader - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamReader(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamReader
 
DefaultStreamReader.Input - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamReader.Input() - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
DefaultStreamWriter - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamWriter(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamWriter
 
DefaultStreamWriter.Output - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamWriter.Output(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
DefaultWorkerThread - Class in org.glassfish.grizzly.threadpool
Default Grizzly worker thread implementation
DefaultWorkerThread(AttributeBuilder, String, ThreadLocalPool, Runnable) - Constructor for class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
deflate(Deflater, MemoryManager) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Writes next block of compressed data to the output stream.
DelayedExecutor - Class in org.glassfish.grizzly.utils
 
DelayedExecutor(ExecutorService) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor
 
DelayedExecutor(ExecutorService, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor
 
DelayedExecutor.DelayQueue<E> - Class in org.glassfish.grizzly.utils
 
DelayedExecutor.DelayQueue(DelayedExecutor.Worker<E>, DelayedExecutor.Resolver<E>) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
DelayedExecutor.Resolver<E> - Interface in org.glassfish.grizzly.utils
 
DelayedExecutor.Worker<E> - Interface in org.glassfish.grizzly.utils
 
delayedQueue - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DelayFilter - Class in org.glassfish.grizzly.utils
Filter which pauses protocol chain processing for a certain time.
DelayFilter(long, long) - Constructor for class org.glassfish.grizzly.utils.DelayFilter
 
deregister(JmxObject) - Method in class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
Unregister Grizzly JmxObject.
deregisterChannel(SelectorRunner, SelectableChannel) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
deregisterChannel(SelectorRunner, SelectableChannel) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Deregister the channel from the SelectorRunner's Selector.
deregisterChannelAsync(SelectorRunner, SelectableChannel, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
deregisterChannelAsync(SelectorRunner, SelectableChannel, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Deregister the channel from the SelectorRunner's Selector.
deregisterKeyInterest(SelectorRunner, SelectionKey, int) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
deregisterKeyInterest(SelectorRunner, SelectionKey, int) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
destroy() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
destroy() - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
detachSelectorRunner() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
disableIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
disableIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
dispose() - Method in interface org.glassfish.grizzly.Buffer
Notify the allocator that the space for this Buffer is no longer needed.
dispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
dispose() - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
dispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
dispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
disposeBuffer() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
disposeStackTrace - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
disposeStackTrace - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
doHandshakeStep(SSLEngine, FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
doHandshakeStep() - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
doNotify() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
doRead(Connection, AsyncReadQueueRecord) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Performs real read on the NIO channel
doSelect() - Method in class org.glassfish.grizzly.nio.SelectorRunner
This method handle the processing of all Selector's interest op (OP_ACCEPT,OP_READ,OP_WRITE,OP_CONNECT) by delegating to its Handler.
doWork() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
doWork(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Worker
 
drain(Queue<Runnable>, Collection<Runnable>) - Static method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
drainAllCharsets() - Static method in class org.glassfish.grizzly.utils.Charsets
Remove all preloaded charsets.
drainTo(Collection<? super E>) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
drainTo(Collection<? super E>, int) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
dumpErr(Object) - Static method in class org.glassfish.grizzly.utils.Utils
 
dumpOut(Object) - Static method in class org.glassfish.grizzly.utils.Utils
 
duplicate() - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer that shares this buffer's content.
duplicate() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
duplicate() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
duplicate() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 

E

EchoFilter - Class in org.glassfish.grizzly.utils
Echo Filter implementation
EchoFilter() - Constructor for class org.glassfish.grizzly.utils.EchoFilter
 
EMatchFinderTypeBT2 - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
EMatchFinderTypeBT4 - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
EMPTY_BUFFER - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_BYTE_BUFFER - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_BYTE_BUFFER_ARRAY - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_RECORD_SPACE_VALUE - Static variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
EmptyCompletionHandler<E> - Class in org.glassfish.grizzly
Empty implementation for CompletionHandler interface.
EmptyCompletionHandler() - Constructor for class org.glassfish.grizzly.EmptyCompletionHandler
 
EmptyIOEventProcessingHandler - Class in org.glassfish.grizzly
Empty IOEventProcessingHandler implementation.
EmptyIOEventProcessingHandler() - Constructor for class org.glassfish.grizzly.EmptyIOEventProcessingHandler
 
ENABLE_INTEREST_PROCESSING_HANDLER - Static variable in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
enabledCipherSuites - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
The list of cipher suite
enabledProtocols - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
the list of protocols
enableIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
enableIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
encode(RangeEncoder, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
encode(short[], int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
encode(Transformer<E, Buffer>, E) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
encode(Transformer<E, Buffer>, E, CompletionHandler<Stream>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
encode(Transformer<E, Buffer>, E) - Method in interface org.glassfish.grizzly.streams.StreamWriter
 
encode(Transformer<E, Buffer>, E, CompletionHandler<Stream>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
 
encodeDirectBits(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
Encoder - Class in org.glassfish.grizzly.compression.lzma.impl
RangeEncoder
Encoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
enque(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
enque(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Execute task in a selector thread.
ensureBufferCapacity(int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
ensureBufferCapacity(int) - Method in interface org.glassfish.grizzly.streams.Output
 
ensureBufferCapacity(int) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
equals(Object) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
equals(Object) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
equals(Object) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
equalVersion(int, int) - Static method in class org.glassfish.grizzly.Grizzly
Checks if current Grizzly framework version equals to one passed
evaluate() - Method in interface org.glassfish.grizzly.attributes.NullaryFunction
Returns default Attribute value.
event - Variable in class org.glassfish.grizzly.filterchain.FilterChainContext
Context associated event, if EVENT operation
ExceptionHandler - Interface in org.glassfish.grizzly.utils
 
ExceptionHandler.Severity - Enum in org.glassfish.grizzly.utils
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Notification about exception, occurred on the FilterChain
exceptionOccurred(FilterChainContext, Throwable) - Method in interface org.glassfish.grizzly.filterchain.Filter
Notification about exception, occurred on the FilterChain
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.utils.LogFilter
 
Exceptions - Class in org.glassfish.grizzly.utils
Exceptions utilities.
Exceptions() - Constructor for class org.glassfish.grizzly.utils.Exceptions
 
execute(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Execute this FilterChain.
execute(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
Method processes occurred IOEvent on this FilterChain.
execute(Filter, FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
execute(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
execute(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Execute task in a selector thread.
execute(Connection, IOEvent, Processor, IOEventProcessingHandler) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
execute(Context) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.FixedThreadPool
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
executeChainPart(FilterChainContext, FilterExecutor, int, int, DefaultFilterChain.FiltersState) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Sequentially lets each Filter in chain to process IOEvent.
executeDelegatedTask(SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
Complete handshakes operations.
executeFilter(FilterExecutor, Filter, FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Execute the Filter, using specific FilterExecutor and FilterChainContext.
executeIoEvent(Connection, IOEvent) - Method in interface org.glassfish.grizzly.IOStrategy
The SelectorRunner will invoke this method to allow the strategy implementation to decide how the IOEvent will be handled.
executeIoEvent(Connection, IOEvent, boolean) - Method in interface org.glassfish.grizzly.IOStrategy
The SelectorRunner will invoke this method to allow the strategy implementation to decide how the IOEvent will be handled.
executeIoEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.LeaderFollowerNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
executeIoEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.WorkerThreadIOStrategy
 
EXPECTING_MORE_OPTION - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
 

F

fail(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fail(FilterChainContext, Throwable) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fail(Throwable) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
failed(Throwable) - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was failed.
failed(Throwable) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was failed.
failed(Throwable) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
failed(Throwable) - Method in class org.glassfish.grizzly.streams.TransformerInput.TransformerCompletionHandler
 
failed(Throwable) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
failure(Throwable) - Method in interface org.glassfish.grizzly.impl.FutureImpl
Notify about the failure, occurred during asynchronous operation execution.
failure(Throwable) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Should not be called for ReadyFutureImpl
failure(Throwable) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Notify about the failure, occurred during asynchronous operation execution.
failure - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
failure(Throwable) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Notify about the failure, occured during asynchronous operation execution.
FileTransfer - Class in org.glassfish.grizzly
A simple class that abstracts FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel) for use with Grizzly 2.0 AsyncQueueWriter.
FileTransfer(File) - Constructor for class org.glassfish.grizzly.FileTransfer
Constructs a new FileTransfer instance backed by the specified File.
FileTransfer(File, long, long) - Constructor for class org.glassfish.grizzly.FileTransfer
Constructs a new FileTransfer instance backed by the specified File.
fill(Buffer, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the Buffer with the specific byte value.
fill(Buffer, int, int, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the Buffer's part [position, limit) with the specific byte value starting from the Buffer's position won't be changed.
fill(ByteBuffer, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the ByteBuffer with the specific byte value.
fill(ByteBuffer, int, int, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the ByteBuffer's part [position, limit) with the specific byte value starting from the ByteBuffer's position won't be changed.
Filter - Interface in org.glassfish.grizzly.filterchain
A Filter encapsulates a unit of processing work to be performed, whose purpose is to examine and/or modify the state of a transaction that is represented by a FilterChainContext.
FilterChain - Interface in org.glassfish.grizzly.filterchain
This class implement the "Chain of Responsibility" pattern (for more info, take a look at the classic "Gang of Four" design patterns book).
FilterChainBuilder - Class in org.glassfish.grizzly.filterchain
FilterChainBuilder.StatelessFilterChainBuilder implementation, which is responsible for constructing FilterChains.
FilterChainBuilder.StatelessFilterChainBuilder - Class in org.glassfish.grizzly.filterchain
 
FilterChainBuilder.StatelessFilterChainBuilder() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainBuilder.StatelessFilterChainBuilder
 
FilterChainContext - Class in org.glassfish.grizzly.filterchain
FilterChain Context implementation.
FilterChainContext() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainContext
 
FilterChainContext.CompletionListener - Interface in org.glassfish.grizzly.filterchain
The interface, which represents a listener, which will be notified, once FilterChainContext processing is complete.
FilterChainContext.CopyListener - Interface in org.glassfish.grizzly.filterchain
The interface, which represents a listener, which will be notified, after FilterChainContext.copy() is called.
FilterChainContext.Operation - Enum in org.glassfish.grizzly.filterchain
 
FilterChainContext.State - Enum in org.glassfish.grizzly.filterchain
 
FilterChainContext.TransportContext - Class in org.glassfish.grizzly.filterchain
 
FilterChainContext.TransportContext() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
FilterChainEnabledTransport - Interface in org.glassfish.grizzly.filterchain
Common interface for Transports, which support FilterChains.
FilterChainEvent - Interface in org.glassfish.grizzly.filterchain
 
FilterChainProcessorSelector - Class in org.glassfish.grizzly.filterchain
ProcessorSelector implementation, which delegates processing of IOEvent to the FilterChain.
FilterChainProcessorSelector(FilterChainBuilder) - Constructor for class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
 
FilterExecutor - Interface in org.glassfish.grizzly.filterchain
Executes appropriate Filter processing method to process occurred IOEvent.
filters - Variable in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
The list of Filters this chain will invoke.
finalize() - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
find(Class<T>, ClassLoader) - Static method in class org.glassfish.grizzly.utils.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the given class loader.
find(Class<T>) - Static method in class org.glassfish.grizzly.utils.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the context class loader.
FINE_GRIZZLY_ASYNCQUEUE_ERROR_NOCALLBACK_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0009: No callback available to be notified about AsyncQueue error: {0}
FINE_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_DEBUG(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
Character decoding failed.
FINE_GRIZZLY_HTTP_PARAMETERS_NOEQUAL(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
Parameter starting at position [{0}] and ending at position [{1}] with a value of [{2}] was not followed by an '=' character
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Finishes to compress data to the output stream without closing the underlying stream.
fireEventDownstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fireEventDownstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fireEventUpstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fireEventUpstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fireIOEvent(IOEvent, Connection, IOEventProcessingHandler) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
fireIOEvent(IOEvent, Connection, IOEventProcessingHandler) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
fireIOEvent(Connection, IOEvent, IOEventProcessingHandler, Logger) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
fireIOEvent(IOEvent, Connection, IOEventProcessingHandler) - Method in interface org.glassfish.grizzly.Transport
Fires specific IOEvent on the Connection
FixedThreadPool - Class in org.glassfish.grizzly.threadpool
Minimalistic fixed thread pool to allow for nice scalability if a good Queue impl is used.
FixedThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.FixedThreadPool
 
flip() - Method in interface org.glassfish.grizzly.Buffer
Flips this buffer.
flip() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
flip() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
flip() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
flush() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
flush(Connection, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
flush(Connection, CompletionHandler<WriteResult>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
flush(CompletionHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter
 
flush() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Cause the overflow handler to be called even if buffer is not full.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Cause the overflow handler to be called even if buffer is not full.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
flush(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Output
Make sure that all data that has been written is flushed from the stream to its destination.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
flush() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Make sure that all data that has been written is flushed from the stream to its destination.
flush(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Make sure that all data that has been written is flushed from the stream to its destination.
flush() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
flushData() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
FOREVER - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
FOREVER_SPECIAL - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
forgetWritePossible(WriteHandler) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
format(LogRecord) - Method in class org.glassfish.grizzly.utils.LoggingFormatter
Format the record to include the Thread that logged this record.
future - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
FutureImpl<R> - Interface in org.glassfish.grizzly.impl
Future interface, which has full control over the state.
Futures - Class in org.glassfish.grizzly.utils
Set of utilities.
Futures() - Constructor for class org.glassfish.grizzly.utils.Futures
 

G

GenericAdapter<K,V> - Interface in org.glassfish.grizzly.utils
Generic Adapter interface.
get() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueWriter.Reentrant
 
get(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeHolder.
get(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeStorage.
get() - Method in interface org.glassfish.grizzly.Buffer
Relative get method.
get(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method.
get(byte[]) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(byte[], int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(ByteBuffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(ByteBuffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
get(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
get() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
get(long, TimeUnit) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
get() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
get(long, TimeUnit) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
get(ByteBuffer, byte[], int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
get() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
Get the cached object with the given type index from cache.
get() - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
Get (peek) the object from cache.
getActiveThreadsCount() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
getAddress() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get address, associated with the current IOEvent processing.
getAlgorithm() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getAppender() - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FilterStateElement
 
getArguments() - Method in interface org.glassfish.grizzly.localization.Localizable
Returns the arguments for message formatting.
getArguments() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getArray() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getArray() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the underlying array.
getArrayCopy() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the copy of the underlying array.
getAsyncQueueIO() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueEnabledTransport
Get asynchronous queue implementation.
getAsyncQueueIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getAsyncQueueIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getAsyncReadQueue() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAsyncWriteQueue() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Return an object based on a name.
getAttribute(int) - Method in interface org.glassfish.grizzly.attributes.IndexedAttributeAccessor
Internal method for dynamic attribute support.
getAttribute(String) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Return an object based on a name.
getAttribute(int) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
Internal method for dynamic attribute support.
getAttribute(String) - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Return an object based on a name.
getAttributeBuilder() - Method in class org.glassfish.grizzly.AbstractTransport
Get Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
getAttributeBuilder() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Get AttributeBuilder, associated with this holder
getAttributeBuilder() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Get AttributeBuilder, associated with this holder
getAttributeBuilder() - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Get AttributeBuilder, associated with this holder
getAttributeBuilder() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getAttributeBuilder() - Method in interface org.glassfish.grizzly.Transport
Get Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
getAttributeByIndex(int) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
getAttributeByName(String) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
getAttributeNames() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Return a Set of attribute names.
getAttributeNames() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Return a Set of attribute names.
getAttributeNames() - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Return a Set of attribute names.
getAttributes() - Method in interface org.glassfish.grizzly.attributes.AttributeStorage
Get associated AttributeHolder.
getAttributes() - Method in class org.glassfish.grizzly.Context
Get attributes (AttributeHolder), associated with the processing Context.
getAttributes() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get associated AttributeHolder.
getAttributes() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAttributes() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getBoundAddresses() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getBuffer() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
getBuffer() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
getBuffer() - Method in interface org.glassfish.grizzly.streams.Input
Return the Input's Buffer.
getBuffer() - Method in interface org.glassfish.grizzly.streams.Output
Return the Input's Buffer.
getBuffer() - Method in class org.glassfish.grizzly.streams.StreamInput
 
getBuffer() - Method in class org.glassfish.grizzly.streams.StreamOutput
 
getBuffer() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
Get the result Buffer (not flipped).
getBufferAppender(boolean) - Static method in class org.glassfish.grizzly.memory.Buffers
Get the Appender which knows how to append Buffers.
getBufferedSize() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
getBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
getBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
getByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
getBytesRead() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getBytesWritten() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getCertificates() - Method in class org.glassfish.grizzly.ssl.SSLFilter.CertificateEvent
 
getChannel() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getChannel() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getChannelDistributor() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getChar() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a char value.
getChar(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a char value.
getChar() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getChar(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getChar() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getChar(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getChar() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getChar(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getCharset() - Method in class org.glassfish.grizzly.utils.StringDecoder
 
getCharset() - Method in class org.glassfish.grizzly.utils.StringEncoder
 
getCharsetDecoder(Charset) - Static method in class org.glassfish.grizzly.utils.Charsets
Return the Charset's CharsetDecoder.
getCharsetEncoder(Charset) - Static method in class org.glassfish.grizzly.utils.Charsets
Return the Charset's CharsetEncoder.
getChunkSize() - Method in class org.glassfish.grizzly.utils.ChunkingFilter
 
getCipherSuite() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The cipher suite being used on this connection.
getCipherSuite() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getClazz() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getClientSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getClientSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getClientSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getClientSSLEngineConfig() - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
getCompletionHandler() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
getCompletionHandler() - Method in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
getCompletionHandler() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getCondition() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getConfig() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getConfiguration() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
getConnection() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
getConnection() - Method in class org.glassfish.grizzly.Context
Get the processing Connection.
getConnection() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the Connection, associated with the current processing.
getConnection() - Method in class org.glassfish.grizzly.ReadResult
Get the Connection data were read from.
getConnection() - Method in interface org.glassfish.grizzly.Result
Get Connection, associated with the result.
getConnection() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the Connection this StreamReader belongs to.
getConnection() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Get the Connection this StreamWriter belongs to.
getConnection() - Method in interface org.glassfish.grizzly.streams.Stream
Get the Connection this StreamReader belongs to.
getConnection() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Get the Connection this StreamWriter belongs to.
getConnection() - Method in class org.glassfish.grizzly.WriteResult
Get the Connection data were read from.
getConnectionForKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
getConnectionForKey(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
getConnectionMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the monitoring configuration for Transport Connections.
getConnectionMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the monitoring configuration for Transport Connections.
getConnectionTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getConnectionTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getConnectionTimeout() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getConnectionTimeout() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
getConnectTimeout() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getConnectTimeout() - Method in class org.glassfish.grizzly.nio.transport.jmx.UDPNIOTransport
 
getCorePoolSize() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getCorePoolSize() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getCrc32() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getCrc32() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
getCurrentAllocatedThreadCount() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getCurrentPoolSize() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
getCurrentResult() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
getCurrentTaskCount() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getData() - Method in class org.glassfish.grizzly.ProcessorResult
Get the ProcessorResult extra data.
getDecoder() - Method in interface org.glassfish.grizzly.Codec
 
getDecoder() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getDecoder() - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
getDecoder() - Method in class org.glassfish.grizzly.ssl.SSLCodec
getDecodeStatus() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getDefaultThreadFactory() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getDeflater() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
getDictionarySize() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getDigest() - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
getDotedVersion() - Static method in class org.glassfish.grizzly.Grizzly
Return the dotted version of the current release.
getDouble() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a double value.
getDouble(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a double value.
getDouble() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getDouble() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getDouble() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getDst() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getDst() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getDstAddress() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getDstAddress() - Method in class org.glassfish.grizzly.WriteResult
Get the destination address, the message was written to.
getEnabledCipherSuites() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getEnabledProtocols() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getEncoder() - Method in interface org.glassfish.grizzly.Codec
 
getEncoder() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getEncoder() - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
getEncoder() - Method in class org.glassfish.grizzly.ssl.SSLCodec
getEndIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getErrorCode() - Method in class org.glassfish.grizzly.TransformationResult
 
getErrorDescription() - Method in class org.glassfish.grizzly.TransformationResult
 
getExternalRemainder() - Method in class org.glassfish.grizzly.TransformationResult
 
getFilterChain() - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Returns the FilterChain, which is executing this Filter on the current thread.
getFilterChain() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get FilterChain, which runs the Filter.
getFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getFirst() - Method in class org.glassfish.grizzly.utils.Pair
 
getFloat() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a float value.
getFloat(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a float value.
getFloat() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getFloat() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getFloat() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getForkAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getFromCache(ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Get the cached object with the given type index from cache.
getFromCache(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
Get the cached object with the given type index from cache.
getFuture() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getHeaderFlag() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getHeaderParseStateValue() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getIndex() - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
getIndex() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getIndexByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getIndexedAttributeAccessor() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
If AttributeHolder supports attribute access by index - it will return an IndexedAttributeAccessor, which will make Attribute access as fast as access to array element.
getIndexedAttributeAccessor() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Returns IndexedAttributeAccessor for accessing Attributes by index.
getIndexedAttributeAccessor() - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Always returns null, as NamedAttributeHolder doesn't support indexing.
getInflater() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getInitialBufferSize(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInitialLimit(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInitialMessageSize() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getInitialMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getInitialPosition(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.LeaderFollowerNIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.WorkerThreadIOStrategy
 
getInt() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading an int value.
getInt(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading an int value.
getInt() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getInt(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getInt() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getInt(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getInt() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getInt(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getInterceptor() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
getInternalContext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the general Grizzly Context this filter context wraps.
getInvokeAction(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to process next Filter in chain.
getInvokeAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to process next Filter in chain.
getIoEvent() - Method in class org.glassfish.grizzly.Context
Get the processing IOEvent.
getIOEvents(int) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
getIOEvents(int) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
getIOStrategy() - Method in class org.glassfish.grizzly.AbstractTransport
Get the IOStrategy implementation, which will be used by Transport to process IOEvent.
getIOStrategy() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getIOStrategy() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getIOStrategy() - Method in interface org.glassfish.grizzly.Transport
Get the IOStrategy implementation, which will be used by Transport to process IOEvent.
getJdkVersion() - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
getJmxName() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getJmxName() - Method in class org.glassfish.grizzly.monitoring.jmx.JmxObject
 
getJmxName() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getJmxName() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getKeepAlive() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getKeepAliveTime(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getKernelThreadPool() - Method in class org.glassfish.grizzly.AbstractTransport
getKernelThreadPool() - Method in interface org.glassfish.grizzly.Transport
 
getKernelThreadPoolConfig() - Method in class org.glassfish.grizzly.AbstractTransport
getKernelThreadPoolConfig() - Method in interface org.glassfish.grizzly.Transport
 
getKey() - Method in interface org.glassfish.grizzly.localization.Localizable
Gets the key in the resource bundle.
getKey() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getKeySize() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
Get the keysize.
getKeySize() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
Copied from org.apache.catalina.valves.CertificateValve
getLastError() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getLastResult(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
getLastResult() - Method in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
getLastResult(AttributeStorage) - Method in interface org.glassfish.grizzly.Transformer
Gets the last returned Transformer result.
getLastSelectedKeysCount() - Method in class org.glassfish.grizzly.nio.SelectorRunner
Number of SelectionKeys, which were selected last time.
getLc() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getLenToPosState(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
getLevel() - Method in class org.glassfish.grizzly.utils.LogFilter
 
getLimit(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getLimit(Buffer) - Method in class org.glassfish.grizzly.memory.BufferArray
 
getLimit(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
getLinger() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getLinger() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getLinger() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getLocalAddress() - Method in interface org.glassfish.grizzly.Connection
Get the connection local address
getLocalAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Returns the local address of this Connection, or null if it is unconnected.
getLocalAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Returns the local address of this Connection, or null if it is unconnected.
getLocale() - Method in class org.glassfish.grizzly.localization.Localizer
 
getLogger() - Method in class org.glassfish.grizzly.utils.LogFilter
 
getLong() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a long value.
getLong(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a long value.
getLong() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getLong(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getLong() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getLong(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getLong() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getLong(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getLower() - Method in class org.glassfish.grizzly.PortRange
 
getLp() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getLTQInstance() - Static method in class org.glassfish.grizzly.utils.DataStructures
 
getLTQInstance(Class<T>) - Static method in class org.glassfish.grizzly.utils.DataStructures
 
getMaintenance() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMajor() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMajorVersion() - Static method in class org.glassfish.grizzly.Grizzly
Get Grizzly framework major version
getMatches(int[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
getMatchFinder() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getMatchLen(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getMaxAllowedThreads() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getMaxAsyncWriteQueueSize() - Method in interface org.glassfish.grizzly.Connection
Get the max size (in bytes) of asynchronous write queue associated with connection.
getMaxAsyncWriteQueueSize() - Method in class org.glassfish.grizzly.nio.NIOConnection
Get the max size (in bytes) of asynchronous write queue associated with connection.
getMaxAsyncWriteQueueSizeInBytes() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getMaxAsyncWriteQueueSizeInBytes() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
getMaxBufferSize() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
getMaxPendingBytesPerConnection() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
 
getMaxPendingBytesPerConnection() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
getMaxPendingBytesPerConnection() - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
getMaxPoolSize() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getMaxQueueSize() - Method in interface org.glassfish.grizzly.asyncqueue.TaskQueue.MutableMaxQueueSize
 
getMaxSmallBufferSize() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
getMaxThreadBufferSize() - Method in class org.glassfish.grizzly.memory.jmx.ByteBufferManager
 
getMaxThreadBufferSize() - Method in class org.glassfish.grizzly.memory.jmx.HeapMemoryManager
 
getMaxWriteReentrants() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Returns the maximum number of write() method reentrants a thread is allowed to made.
getMaxWriteReentrants() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Returns the maximum number of write() method reentrants a thread is allowed to made.
getMemoryManager() - Method in class org.glassfish.grizzly.AbstractTransformer
 
getMemoryManager() - Method in class org.glassfish.grizzly.AbstractTransport
Get the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
getMemoryManager() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getMemoryManager() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getMemoryManager() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
A simple alias for FilterChainContext.getConnection().getTransport().getMemoryManager().
getMemoryManager() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getMemoryManager() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getMemoryManager() - Method in interface org.glassfish.grizzly.Transport
Get the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
getMemoryManagerType() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getMemoryPool() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getMessage() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
getMessage() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get message object, associated with the current processing.
getMessage(String, Object...) - Method in class org.glassfish.grizzly.localization.LocalizableMessageFactory
 
getMessage() - Method in class org.glassfish.grizzly.ReadResult
Get the message, which was read.
getMessage() - Method in class org.glassfish.grizzly.TransformationResult
 
getMessage() - Method in class org.glassfish.grizzly.WriteResult
Get the message, which was read.
getMessageCloner() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
getMinor() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMinorVersion() - Static method in class org.glassfish.grizzly.Grizzly
Get Grizzly framework minor version
getMomentumQueueSize() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the Transport monitoring configuration MonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.Connection
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Return the object associated JmxMonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.monitoring.jmx.JmxMonitoringAware
Return the object associated JmxMonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.monitoring.MonitoringAware
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.nio.NIOConnection
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Return the object associated JmxMonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
Return the object associated JmxMonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the Transport monitoring configuration MonitoringConfig.
getMonitoringProbes() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Get the ConnectionProbe, which are registered on the Connection.
getName() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the Transport name.
getName() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
getName() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
getName() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
Get the Transformer name.
getName() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Get the Transformer name.
getName() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getName() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getName() - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
getName() - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
getName() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getName() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getName() - Method in interface org.glassfish.grizzly.Transformer
Get the Transformer name.
getName() - Method in interface org.glassfish.grizzly.Transport
Gets the Transport name.
getName() - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
getName() - Method in class org.glassfish.grizzly.utils.StringDecoder
 
getName() - Method in class org.glassfish.grizzly.utils.StringEncoder
 
getNamePrefix() - Method in class org.glassfish.grizzly.AbstractTransformer
 
getNextFilter(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
getNIOChannelDistributor() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getNIOChannelDistributor() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getNumAvailableBytes() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getNumFastBytes() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getOpenConnectionsCount() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getPb() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getPeerAddress() - Method in interface org.glassfish.grizzly.Connection
Get the connection peer address
getPeerAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getPeerAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getPeerCertificateChain(SSLEngine, FilterChainContext, boolean) - Method in class org.glassfish.grizzly.ssl.SSLFilter
Obtains the certificate chain for this SSL session.
getPeerCertificateChain() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The client certificate chain (if any).
getPeerCertificateChain(boolean) - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The client certificate chain (if any).
getPeerCertificateChain() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getPeerCertificateChain(boolean) - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getPendingTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getPoolAllocatedBytes() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getPoolName() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getPoolReleasedBytes() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getPoolType() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getPosition(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getPosition(Buffer) - Method in class org.glassfish.grizzly.memory.BufferArray
 
getPosition(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
getPostponedTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getPreviousFilter(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
getPrice(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
getPrice(int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPrice0(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPrice1(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPriority() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getProbes() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Get the the monitoring probes, which are registered on the objet.
getProbes() - Method in class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
Get the the monitoring probes, which are registered on the objet.
getProbesUnsafe() - Method in class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
Get the monitoring probes array (direct).
getProcessedSizeAdd() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getProcessingHandler() - Method in class org.glassfish.grizzly.Context
 
getProcessor() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Get the default Processor to process IOEvent, occurring on connection phase.
getProcessor() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
getProcessor() - Method in interface org.glassfish.grizzly.Connection
Gets the default Processor, which will process Connection I/O events.
getProcessor() - Method in class org.glassfish.grizzly.Context
Get the Processor, which is responsible to process the IOEvent.
getProcessor() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getProcessor() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getProcessor() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
getProcessor() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
getProcessor() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getProcessor() - Method in interface org.glassfish.grizzly.Transport
Gets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
getProcessorSelector() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Gets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
getProcessorSelector() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
getProcessorSelector() - Method in interface org.glassfish.grizzly.Connection
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Connection's Processor is null.
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
getProcessorSelector() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getProcessorSelector() - Method in interface org.glassfish.grizzly.Transport
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
getPushBackHandler() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getPushBackHandler() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
The PushBackHandler passed along with one of the Writer's write(...) method call.
getPushBackHandler() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
getQueue() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Get the queue of tasks, which will be processed asynchronously
getQueue() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getQueue() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getQueueLimit() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getReadBufferSize() - Method in class org.glassfish.grizzly.AbstractTransport
Get the default size of Buffers, which will be allocated for reading data from Transport's Connections.
getReadBufferSize() - Method in interface org.glassfish.grizzly.Connection
Get the default size of Buffers, which will be allocated for reading data from Connection.
getReadBufferSize() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getReadBufferSize() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getReadBufferSize() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getReadBufferSize() - Method in interface org.glassfish.grizzly.Transport
Get the default size of Buffers, which will be allocated for reading data from Transport's Connections.
getReader() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.ImmutableAsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getReader(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Reader implementation, depending on the requested mode.
getReader(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Reader implementation, depending on the requested mode.
getReader(Connection) - Method in interface org.glassfish.grizzly.Transport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in interface org.glassfish.grizzly.Transport
Get the Reader implementation, depending on the requested mode.
getReadSize() - Method in class org.glassfish.grizzly.ReadResult
Get the number of bytes, which were read.
getReadTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Connection
 
getReadTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getReadyThreadBufferSize() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Get the size of local thread memory pool.
getRealAllocatedBytes() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getRefusedBytes() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Get refused bytes counter.
getRerunFilterAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction, which instructs FilterChain to rerun the filter.
getResolver() - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
getResourceBundleName() - Method in interface org.glassfish.grizzly.localization.Localizable
 
getResourceBundleName() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getResult() - Method in interface org.glassfish.grizzly.impl.FutureImpl
Get current result value without any blocking.
getResult() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Get current result value without any blocking.
getResult() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
getResult() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Get current result value without any blocking.
getReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.jmx.UDPNIOTransport
 
getRunnable() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getRunnerThread() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getSecond() - Method in class org.glassfish.grizzly.utils.Pair
 
getSelectionKey() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getSelectionKey() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getSelectionKeyHandler() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectionKeyHandler() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getSelectionKeyHandler() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectionKeyInterest() - Method in enum org.glassfish.grizzly.IOEvent
 
getSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getSelectorHandler() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorHandler() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getSelectorHandler() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectorHandlerRunners() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getSelectorPool() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getSelectorProvider() - Method in class org.glassfish.grizzly.nio.NIOTransport
Get the SelectorProvider to be used by this transport.
getSelectorProvider() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
getSelectorProvider() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectorRunner() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getSelectorRunner() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorRunnersCount() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorThreadPoolConfig() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectTimeout() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
getSelectTimeout() - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
getServerConnectionBackLog() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the default server connection backlog size.
getServerConnectionBackLog() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getServerSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getServerSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getServerSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getServerSSLEngineConfig() - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
getSessionId() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The current session Id.
getSessionId() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getShort() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a short value.
getShort(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a short value.
getShort() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getShort(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getShort() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getShort(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getShort() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getShort(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getSize() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getSource() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader
 
getSrc() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getSrc() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getSrcAddress() - Method in class org.glassfish.grizzly.ReadResult
Get the source address, the message was read from.
getSslContext() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getSSLEngine(AttributeStorage) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
getSSLPacketSize(Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
getStackTrace() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
getStartIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getState() - Method in class org.glassfish.grizzly.AbstractTransport
Return the Transport state controller.
getState(FilterChainContext.Operation, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
getState() - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FilterStateElement
 
getState() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getState() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getState() - Method in interface org.glassfish.grizzly.Transport
Return the Transport state controller.
getState() - Method in class org.glassfish.grizzly.utils.StateHolder
Gets current state Current StateHolder locking mode will be used
getStateLocker() - Method in class org.glassfish.grizzly.utils.StateHolder
Gets Read/Write locker, which is used by this StateHolder
getStatus() - Method in class org.glassfish.grizzly.ProcessorResult
Get the result status.
getStatus() - Method in class org.glassfish.grizzly.TransformationResult
 
getStopAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to stop executing phase.
getStopAction(E, Appender<E>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain stop executing phase.
getStopAction(Appendable) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain stop executing phase.
getStopAction(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain stop executing phase.
getStreamReader(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
Get the Connection StreamReader, to read data from the Connection.
getStreamWriter(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
Get the Connection StreamWriter, to write data to the Connection.
getSuspendAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction, which instructs FilterChain to suspend filter chain execution.
getSuspendingStopAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Deprecated. use FilterChainContext.getForkAction()
getSyncConnectTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
getSyncConnectTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
getTask() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
getTask() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool.SyncThreadWorker
 
getTcpNoDelay() - Method in class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
getTemporarySelectorIO() - Method in interface org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorsEnabledTransport
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
getThis() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getThis() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
getThis() - Method in class org.glassfish.grizzly.NIOTransportBuilder
See: http://www.angelikalanger.com/GenericsFAQ/FAQSections/ProgrammingIdioms.html#FAQ205
getThread() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getThread() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getThreadFactory() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getThreadLocalPool() - Static method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Get thread associated buffer pool.
getThreadName() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
getThreadPool() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
getThreadPoolMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the monitoring configuration for Transport thread pool.
getThreadPoolMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the monitoring configuration for Transport thread pool.
getThreadPoolType() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Get the timeout for StreamWriter I/O operations.
getTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Get the timeout for StreamWriter I/O operations.
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
getTimeout(FilterChainContext) - Method in interface org.glassfish.grizzly.utils.IdleTimeoutFilter.TimeoutResolver
 
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
getTimeoutMillis(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
getTotalAllocatedBytes() - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
getTotalAllocatedThreadCount() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getTotalCompletedTasksCount() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getTotalConnectionsCount() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getTotalTaskQueueOverflowCount() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
getTransactionMonitor() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getTransactionTimeout(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getTransactionTimeout(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getTransactionTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getTransport() - Method in interface org.glassfish.grizzly.Connection
Get the Transport, to which this Connection belongs to.
getTransport() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getTransport() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getTransport() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
getTransport() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
getTransportContext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the TransportFilter related context.
getTransportFilter() - Method in interface org.glassfish.grizzly.filterchain.FilterChainEnabledTransport
Get transport Filter, which is aware of Transport specifics; knows how to read/write from/to Transport specific Connection streams.
getTransportFilter() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getTransportFilter() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getTransportFilter0(Transport) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Get default Transport specific transport filter.
getTransportSelectorRunners() - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
getUpdate() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getUpper() - Method in class org.glassfish.grizzly.PortRange
 
getValue(AttributeStorage, Attribute<T>, T) - Static method in class org.glassfish.grizzly.AbstractTransformer
 
getWaitingConsumerCount() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
getWaitingConsumerCount() - Method in interface org.glassfish.grizzly.utils.TransferQueue
Returns an estimate of the number of consumers waiting to dequeue elements via take or poll.
getWorkerThreadPool() - Method in class org.glassfish.grizzly.AbstractTransport
Get a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
getWorkerThreadPool(Connection) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
getWorkerThreadPool() - Method in interface org.glassfish.grizzly.Transport
Get a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
getWorkerThreadPoolConfig() - Method in class org.glassfish.grizzly.AbstractTransport
getWorkerThreadPoolConfig() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getWorkerThreadPoolConfig() - Method in interface org.glassfish.grizzly.Transport
 
getWritableMessage() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getWriteBufferSize() - Method in class org.glassfish.grizzly.AbstractTransport
Get the default size of Buffers, which will be allocated for writing data to Transport's Connections.
getWriteBufferSize() - Method in interface org.glassfish.grizzly.Connection
Get the default size of Buffers, which will be allocated for writing data to Connection.
getWriteBufferSize() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getWriteBufferSize() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
getWriteBufferSize() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getWriteBufferSize() - Method in interface org.glassfish.grizzly.Transport
Get the default size of Buffers, which will be allocated for writing data to Transport's Connections.
getWriter() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.ImmutableAsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getWriter(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Writer implementation, depending on the requested mode.
getWriter(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Writer implementation, depending on the requested mode.
getWriter(Connection) - Method in interface org.glassfish.grizzly.Transport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in interface org.glassfish.grizzly.Transport
Get the Writer implementation, depending on the requested mode.
getWriteReentrant() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Returns the current write reentrants counter.
getWriteReentrant() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Returns the current write reentrants counter.
getWriteTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Connection
 
getWriteTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getWrittenSize() - Method in class org.glassfish.grizzly.WriteResult
Get the number of bytes, which were written.
getX509Certificates(SSLSession) - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
Grizzly - Class in org.glassfish.grizzly
Class contains information about Grizzly framework.
Grizzly() - Constructor for class org.glassfish.grizzly.Grizzly
 
GrizzlyExecutorService - Class in org.glassfish.grizzly.threadpool
 
GrizzlyExecutorService(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
GrizzlyFuture<R> - Interface in org.glassfish.grizzly
Grizzly Future implementation, which might be recycled and reused.
GrizzlyJmxManager - Class in org.glassfish.grizzly.monitoring.jmx
Grizzly JMX manager
GrizzlyJmxManager(ManagedObjectManager) - Constructor for class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
 
GZipDecoder - Class in org.glassfish.grizzly.compression.zip
This class implements a Transformer which decodes data represented in the GZIP format.
GZipDecoder() - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder
 
GZipDecoder(int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder
 
GZipDecoder.DecodeStatus - Enum in org.glassfish.grizzly.compression.zip
 
GZipDecoder.GZipInputState - Class in org.glassfish.grizzly.compression.zip
 
GZipDecoder.GZipInputState() - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
GZipEncoder - Class in org.glassfish.grizzly.compression.zip
This class implements a Transformer which encodes plain data to the GZIP format.
GZipEncoder() - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder
 
GZipEncoder(int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder
 
GZipEncoder.GZipOutputState - Class in org.glassfish.grizzly.compression.zip
 
GZipEncoder.GZipOutputState() - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
GZipFilter - Class in org.glassfish.grizzly.compression.zip
This class implements a Filter which encodes/decodes data in the GZIP format.
GZipFilter() - Constructor for class org.glassfish.grizzly.compression.zip.GZipFilter
Construct GZipFilter using default buffer sizes.
GZipFilter(int, int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipFilter
Construct GZipFilter using specific buffer sizes.

H

handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when server channel has accepted the client connection.
handleAccept(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when server channel has accepted the client connection.
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates accept operation to Transport's specific transport filter.
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method perform the clean up of GZIP encoding/decoding state on a closed Connection.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when connection has been closed.
handleClose(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when connection has been closed.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates close operation to Transport's specific transport filter.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when channel gets connected.
handleConnect(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when channel gets connected.
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates connect operation to Transport's specific transport filter.
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Handle custom event associated with the Connection.
handleEvent(FilterChainContext, FilterChainEvent) - Method in interface org.glassfish.grizzly.filterchain.Filter
Handle custom event associated with the Connection.
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates event operation to Transport's specific transport filter.
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method decodes GZIP encoded data stored in FilterChainContext.getMessage() and, as the result, produces a Buffer with a plain data.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when channel will become available for reading.
handleRead(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when channel will become available for reading.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates reading operation to Transport's specific transport filter.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.DelayFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.EchoFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method compresses plain data stored in FilterChainContext.getMessage() and, as the result, produces a Buffer with a GZIP compressed data.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when some data should be written on channel.
handleWrite(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when some data should be written on channel.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates writing operation to Transport's specific transport filter.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.DelayFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handshake(Connection) - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
handshake(Connection, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
handshake(Connection, CompletionHandler<SSLEngine>) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(Connection, CompletionHandler<SSLEngine>, Object) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(Connection, CompletionHandler<SSLEngine>, Object, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(SSLStreamReader, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter
 
handshake(SSLStreamReader, SSLEngineConfigurator, CompletionHandler<SSLEngine>) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter
 
handshakeUnwrap(Connection, SSLEngine, Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
handshakeWrap(Connection, SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
hasAvailable() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Return true if StreamReader has available data, which could be read, or false otherwise.
hasAvailable() - Method in interface org.glassfish.grizzly.streams.StreamReader
Return true if StreamReader has available data, which could be read, or false otherwise.
hashCode() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Returns the current hash code of this buffer.
hashCode() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
hashCode() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
hasInputRemaining(AttributeStorage, K) - Method in interface org.glassfish.grizzly.Transformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
hasInputRemaining(AttributeStorage, String) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
hasNextFilter(FilterChainContext, int) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
hasPreviousFilter(FilterChainContext, int) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
hasRemaining() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Return true if this message has data remaining to be written.
hasRemaining() - Method in interface org.glassfish.grizzly.Buffer
Tells whether there are any elements between the current position and the limit.
hasRemaining() - Method in class org.glassfish.grizzly.FileTransfer
Return true if this message has data remaining to be written.
hasRemaining() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
hasRemaining() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
hasRemaining() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
hasRemaining() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
hasWaitingConsumer() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
hasWaitingConsumer() - Method in interface org.glassfish.grizzly.utils.TransferQueue
Returns true if there is at least one consumer waiting to dequeue an element via take or poll.
heap - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
HeapBuffer - Class in org.glassfish.grizzly.memory
Buffer implementation, which uses the ByteBuffer underneath.
HeapBuffer() - Constructor for class org.glassfish.grizzly.memory.HeapBuffer
 
HeapBuffer(byte[], int, int) - Constructor for class org.glassfish.grizzly.memory.HeapBuffer
 
HeapMemoryManager - Class in org.glassfish.grizzly.memory
A WrapperAware MemoryManager implementation for managing HeapBuffer instances.
HeapMemoryManager() - Constructor for class org.glassfish.grizzly.memory.HeapMemoryManager
 
HeapMemoryManager(int) - Constructor for class org.glassfish.grizzly.memory.HeapMemoryManager
 
HeapMemoryManager - Class in org.glassfish.grizzly.memory.jmx
HeapMemoryManager JMX object.
HeapMemoryManager(HeapMemoryManager) - Constructor for class org.glassfish.grizzly.memory.jmx.HeapMemoryManager
 

I

IDLE_ATTRIBUTE_NAME - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible for tracking Connection activity and closing Connection ones it becomes idle for certain amount of time.
IdleTimeoutFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, IdleTimeoutFilter.TimeoutResolver) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, long, TimeUnit, IdleTimeoutFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, IdleTimeoutFilter.TimeoutResolver, IdleTimeoutFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, DelayedExecutor.Worker<Connection>, IdleTimeoutFilter.TimeoutResolver) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter.TimeoutHandler - Interface in org.glassfish.grizzly.utils
 
IdleTimeoutFilter.TimeoutResolver - Interface in org.glassfish.grizzly.utils
 
incAndGet() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueWriter.Reentrant
 
INCOMPLETE_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
INCOMPLETED - Static variable in interface org.glassfish.grizzly.Interceptor
 
index() - Method in class org.glassfish.grizzly.attributes.Attribute
Return attribute name, which is used as attribute key on indexed AttributeHolders.
IndexedAttributeAccessor - Interface in org.glassfish.grizzly.attributes
The interface declares, that AttributeHolder supports indexed Attribute access.
indexedAttributeAccessor - Variable in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
IndexedAttributeHolder - Class in org.glassfish.grizzly.attributes
AttributeHolder, which supports indexed access to stored Attributes.
IndexedAttributeHolder(AttributeBuilder) - Constructor for class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
IndexedAttributeHolder.IndexedAttributeAccessorImpl - Class in org.glassfish.grizzly.attributes
IndexedAttributeAccessor implementation.
IndexedAttributeHolder.IndexedAttributeAccessorImpl() - Constructor for class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
 
indexOf(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
indexOf(FilterChainContext.Operation, DefaultFilterChain.FILTER_STATE_TYPE) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
indexOf(FilterChainContext.Operation, DefaultFilterChain.FILTER_STATE_TYPE, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
indexOf(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
indexOf(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
indexOf(T[], Object) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Return the element index in the array.
indexOfRemainder(DefaultFilterChain.FiltersState, FilterChainContext.Operation, int, int) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Locates a message remainder in the FilterChain, associated with the Connection.
indexOfType(Class<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Get the index of Filter in chain, which type is filterType, or -1 if the Filter of required type was not found.
indexOfType(Class<? extends Filter>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
Get the index of Filter in chain, which type is filterType, or -1 if the Filter of required type was not found.
indexOfType(Class<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
INFO_GRIZZLY_CONFIGURATION(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0002: Grizzly running on {0}-{1} under JDK version: {2}-{3} Thread Pool: {4} Read Selector: {5} auto-configure: {6} Using Leader/follower IOStrategy: {7} Number of SelectorHandler: {8} SelectionKeyHandler: {9} Context Caching: {10} Maximum Accept Retry: {11} Handler Read/Write I/O Concurrently {12} ProtocolChainHandler: {13}
INFO_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_INFO(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0156: Character decoding failed.
INFO_GRIZZLY_HTTP_PARAMETERS_INVALID_CHUNK(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0155: Invalid chunk starting at byte [{0}] and ending at byte [{1}] with a value of [{2}] ignored
INFO_GRIZZLY_HTTP_PARAMETERS_MULTIPLE_DECODING_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0157: Character decoding failed.
INFO_GRIZZLY_HTTP_PROCESSOR_TASK_NO_BLOCKING_KEEPALIVE_ALGORITHM() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0151: Keep Alive blocking thread algorithm will not be used.
INFO_GRIZZLY_HTTP_PROCESSOR_TASK_NO_KEEPALIVE_ALGORITHM() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0150: No keep alive algorithm will not be used.
INFO_GRIZZLY_HTTP_PROCESSOR_TASK_SOCKET_CHANNEL_REQUEST_HEADERS(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0153: SocketChannel headers {0} are: {1}.
INFO_GRIZZLY_HTTP_PROCESSOR_TASK_SOCKET_CHANNEL_REQUEST_LINE(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0152: SocketChannel request line {0} is: {1}.
INFO_GRIZZLY_HTTP_SELECTOR_THREAD_CONFIG(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0154: " Grizzly running on {0} - {1} under JDK version: {2} - {3} port: {4} Thread Pool: {5} Read Selector: {6} ByteBuffer size: {7} maxHttpHeaderSize: {8} sendBufferSize: {9} maxKeepAliveRequests: {10} keepAliveTimeoutInSeconds: {11} Static File Cache enabled: {12} Static resources directory: {13} Adapter : {14} Asynchronous Request Processing enabled: {15}
INFO_GRIZZLY_START(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0001: Starting Grizzly Framework {0} - {1}
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
init(boolean) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
initBitModels(short[]) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
initBitModels(short[]) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
initFromState(LZMADecoder.LZMAInputState) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
initFromState(LZMADecoder.LZMAInputState) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
initialize(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
initIndexes(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
inner1State - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
inner2State - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
input - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
Input - Interface in org.glassfish.grizzly.streams
 
instance() - Static method in class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
Return the GrizzlyJmxManager instance.
INSTANCE - Static variable in class org.glassfish.grizzly.StandaloneProcessor
 
INSTANCE - Static variable in class org.glassfish.grizzly.StandaloneProcessorSelector
 
intercept(int, Object, R) - Method in interface org.glassfish.grizzly.Interceptor
Callback method is called by Readable, so it is possible to customize reading process.
interceptor - Variable in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
Interceptor<R> - Interface in org.glassfish.grizzly
Handler, which is used to finer control Readable.
interestedIoEventsMask - Variable in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
InWindow - Class in org.glassfish.grizzly.compression.lzma.impl.lz
InWindow
InWindow() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
ioEvent - Variable in class org.glassfish.grizzly.Context
Processing IOEvent
IOEvent - Enum in org.glassfish.grizzly
Enumeration represents the I/O events, occurred on a Connection.
ioEvent2SelectionKeyInterest(IOEvent) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
ioEvent2SelectionKeyInterest(IOEvent) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
IOEventProcessingHandler - Interface in org.glassfish.grizzly
The IOEvent processing handler, which will be notified about changes in IOEvent processing statuses.
IOStrategy - Interface in org.glassfish.grizzly
strategy is responsible for making decision how Runnable task will be run: in current thread, worker thread.
IS_WORKAROUND_SELECTOR_SPIN - Static variable in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
isAllowDirectWrite() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Returns true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
isBlocking - Variable in class org.glassfish.grizzly.AbstractTransport
Transport mode
isBlocking() - Method in class org.glassfish.grizzly.AbstractTransport
Returns the Transport mode.
isBlocking() - Method in interface org.glassfish.grizzly.Connection
 
isBlocking() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
isBlocking - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
isBlocking() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isBlocking() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
isBlocking() - Method in interface org.glassfish.grizzly.Transport
Returns the Transport mode.
isBuffered() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
isBuffered() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
isBuffered() - Method in interface org.glassfish.grizzly.streams.Input
 
isBuffered() - Method in interface org.glassfish.grizzly.streams.Output
 
isBuffered() - Method in class org.glassfish.grizzly.streams.StreamInput
 
isBuffered() - Method in class org.glassfish.grizzly.streams.StreamOutput
 
isCancelled() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
isCancelled - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
isCancelled() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
isChecked() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
isCipherConfigured() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isClientMode() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Will SSLEngine be configured to work in client mode.
isClosed - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
isClosed() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Returns true, if StreamReader has been closed, or false otherwise.
isClosed() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Returns true, if StreamReader has been closed, or false otherwise.
isClosed - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 
isClosed() - Method in interface org.glassfish.grizzly.streams.StreamReader
Returns true, if StreamReader has been closed, or false otherwise.
isClosed() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Returns true, if StreamReader has been closed, or false otherwise.
isCompletionHandlerRegistered - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
isComposite() - Method in interface org.glassfish.grizzly.Buffer
 
isComposite() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isComposite() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isComposite() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isConnected() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
isDebugVM() - Static method in class org.glassfish.grizzly.utils.Utils
 
isDirect() - Method in interface org.glassfish.grizzly.Buffer
Tells whether or not this buffer is direct.
isDirect() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isDirect - Variable in class org.glassfish.grizzly.memory.ByteBufferManager
Is direct ByteBuffer should be used?
isDirect() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns true, if ByteBufferManager works with direct ByteBuffers, or false otherwise.
isDirect() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isDirect() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isDirect() - Method in class org.glassfish.grizzly.memory.jmx.ByteBufferManager
 
isDone() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
isDone - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
isDone() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
isDownstream() - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
isEmpty() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
isEmpty() - Method in class org.glassfish.grizzly.ChainProcessorSelector
isEmpty() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
isEmpty() - Method in class org.glassfish.grizzly.utils.ArraySet
isEmpty() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
isEmptyRecord() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
isExecuteInWorkerThread(IOEvent) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
isExternal() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.FileTransfer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.HeapBuffer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isFinished() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
isFinished() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
isHandshaking(SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
isHeaderWritten() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
isInterested(IOEvent) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Is this Processor interested in processing the i/o event
isInterested(IOEvent) - Method in interface org.glassfish.grizzly.Processor
Is this Processor interested in processing the i/o event
isInterested(IOEvent) - Method in class org.glassfish.grizzly.StandaloneProcessor
StandaloneProcessor is not interested in any IOEvent.
isKeepAlive() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
isKeepAlive() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isLastAllocated(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
isManualIOEventControl - Variable in class org.glassfish.grizzly.Context
 
isManualIOEventControl() - Method in class org.glassfish.grizzly.Context
 
isMaxReentrantsReached(AsyncQueueWriter.Reentrant) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Returns true, if max number of write->completion-handler reentrants has been reached for the passed AsyncQueueWriter.Reentrant object, and next write will happen in the separate thread.
isMaxReentrantsReached(AsyncQueueWriter.Reentrant) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
isNeedClientAuth() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isOpen() - Method in interface org.glassfish.grizzly.Connection
Is Connection open and ready.
isOpen() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isOptimizedForMultiplexing() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Returns true, if TCPNIOTransport is configured to use AsyncQueueWriter, optimized to be used in connection multiplexing mode, or false otherwise.
isOptimizedForMultiplexing() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isOutputBuffered - Variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
isPaused() - Method in class org.glassfish.grizzly.AbstractTransport
isPaused() - Method in interface org.glassfish.grizzly.Transport
 
isProtocolConfigured() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isReadOnly() - Method in interface org.glassfish.grizzly.Buffer
Tells whether or not this buffer is read-only.
isReadOnly() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isReadOnly() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isReadOnly() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isReadWrite(IOEvent) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
isReady(Connection) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReady(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReady(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReallocate() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
Returns true if "reallocate" strategy is used or false otherwise.
isRecycled - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
isReuseAddress - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isReuseAddress - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
isSelectorThread() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
isSelectorThread() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
isSet(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Checks if this attribute is set on the AttributeHolder.
isSet(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Checks if this attribute is set on the AttributeStorage.
isShutdown() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
isShutdown() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
isStandalone - Variable in class org.glassfish.grizzly.AbstractTransport
 
isStandalone() - Method in class org.glassfish.grizzly.AbstractTransport
 
isStandalone() - Method in interface org.glassfish.grizzly.Connection
 
isStandalone - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
isStandalone() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isStandalone() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
isStandalone() - Method in interface org.glassfish.grizzly.Transport
 
isStarted() - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
isStopped() - Method in class org.glassfish.grizzly.AbstractTransport
Returns true, if this Transport is in stopped state, false otherwise.
isStopped() - Method in interface org.glassfish.grizzly.Transport
Returns true, if this Transport is in stopped state, false otherwise.
isSupportBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
isSupportBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
isTcpNoDelay() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
isTcpNoDelay() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isTerminated() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
isTerminated() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
isTrackingThreadCache() - Static method in class org.glassfish.grizzly.Grizzly
 
isUpstream() - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
isWantClientAuth() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
iterator() - Method in class org.glassfish.grizzly.ChainProcessorSelector
iterator() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
iterator() - Method in class org.glassfish.grizzly.utils.ArraySet
iterator() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
iterator() - Method in class org.glassfish.grizzly.utils.ServiceFinder
Returns discovered objects incrementally.

J

JdkVersion - Class in org.glassfish.grizzly.utils
 
JmxMonitoringAware<E> - Interface in org.glassfish.grizzly.monitoring.jmx
The interface, which could be used by the objects, which support JMX monitoring.
JmxMonitoringConfig<E> - Interface in org.glassfish.grizzly.monitoring.jmx
JMX monitoring configuration interface.
JmxObject - Class in org.glassfish.grizzly.monitoring.jmx
Class represents any kind of JMX object in Grizzly.
JmxObject() - Constructor for class org.glassfish.grizzly.monitoring.jmx.JmxObject
 

K

kAlignMask - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kAlignTableSize - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kDicLogSizeMin - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
keepAliveTimeMillis - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
kEndPosModelIndex - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kernelPool - Variable in class org.glassfish.grizzly.AbstractTransport
Kernel thread pool.
kernelPoolConfig - Variable in class org.glassfish.grizzly.AbstractTransport
 
KEY_FACTORY_MANAGER_ALGORITHM - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_SIZE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the key size.
KEY_SIZE_KEY - Static variable in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
KEY_STORE_FILE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_PASSWORD - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_PROVIDER - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_TYPE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
keySize - Variable in class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
kMatchMaxLen - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kMatchMinLen - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumAlignBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumBitPriceShiftBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
kNumFullDistances - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumHighLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenSpecSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
kNumLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenToPosStates - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenToPosStatesBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLitContextBitsMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLitPosStatesBitsEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLowLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLowLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumMidLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumMidLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosModels - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosSlotBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesBitsEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesBitsMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumRepDistances - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumStates - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kStartPosModelIndex - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 

L

lastIndexOf(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
lastIndexOf(IOEvent, DefaultFilterChain.FILTER_STATE_TYPE, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
lastIndexOf(IOEvent, DefaultFilterChain.FILTER_STATE_TYPE) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
lastIndexOf(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
lastMethodResult - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
lastResult - Variable in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
LeaderFollowerNIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in a current threads, and resumes selector thread logic in separate thread.
lengthAttribute - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
lim - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
limit() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's limit.
limit(int) - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's limit.
limit() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
limit(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
limit() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
limit(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
limit() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
limit(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
LinkedTransferQueue<E> - Class in org.glassfish.grizzly.utils
An unbounded TransferQueue based on linked nodes.
LinkedTransferQueue() - Constructor for class org.glassfish.grizzly.utils.LinkedTransferQueue
Creates an initially empty LinkedTransferQueue.
LinkedTransferQueue(Collection<? extends E>) - Constructor for class org.glassfish.grizzly.utils.LinkedTransferQueue
Creates a LinkedTransferQueue initially containing the elements of the given collection, added in traversal order of the collection's iterator.
listen() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
ListFacadeFilterChain - Class in org.glassfish.grizzly.filterchain
FilterChain facade, which implements all the List related methods.
ListFacadeFilterChain(List<Filter>) - Constructor for class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
 
listIterator() - Method in class org.glassfish.grizzly.ChainProcessorSelector
listIterator(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
listIterator() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
listIterator(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
loadProperties(LZMAEncoder.LZMAProperties) - Static method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
Localizable - Interface in org.glassfish.grizzly.localization
Localizable message.
localizableFINE_GRIZZLY_ASYNCQUEUE_ERROR_NOCALLBACK_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableFINE_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_DEBUG(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableFINE_GRIZZLY_HTTP_PARAMETERS_NOEQUAL(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_CONFIGURATION(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_INFO(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_INVALID_CHUNK(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_MULTIPLE_DECODING_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PROCESSOR_TASK_NO_BLOCKING_KEEPALIVE_ALGORITHM() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PROCESSOR_TASK_NO_KEEPALIVE_ALGORITHM() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PROCESSOR_TASK_SOCKET_CHANNEL_REQUEST_HEADERS(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PROCESSOR_TASK_SOCKET_CHANNEL_REQUEST_LINE(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_SELECTOR_THREAD_CONFIG(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_START(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
LocalizableMessage - Class in org.glassfish.grizzly.localization
 
LocalizableMessage(String, String, Object...) - Constructor for class org.glassfish.grizzly.localization.LocalizableMessage
 
LocalizableMessageFactory - Class in org.glassfish.grizzly.localization
 
LocalizableMessageFactory(String) - Constructor for class org.glassfish.grizzly.localization.LocalizableMessageFactory
 
localizableSEVERE_GRIZZLY_COMET_ENGINE_FLUSH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_COMET_ENGINE_INVALID_NOTIFICATION_HANDLER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_COMET_IO_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_COMETD_ONEVENT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_CONFIG_SSL_CLASS_LOAD_FAILED_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_CONFIG_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_DPF_PROCESSOR_TASK_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_GWS_IO_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_CREATE_REQUEST_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_FILTER_INIT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_NON_BLOCKING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_HEADER_TOO_LARGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_URI_TOO_LARGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_RESPONSE_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_SERVICE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_UNKNOWN_FILTER(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_CONTROLER_PROCESS_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_CONTROLLER_START_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_HTTP_PROCESSING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_INVALID_THREAD_FACTORY_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_START() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_LOAD_CLASS_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_MAPPER_NO_CONTEXT_FOUND(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_SSL_CERT_TRANSLATION_FAILED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_SSL_JSSE_ALIAS_NO_KEY_ENTRY(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_SSL_JSSE_INVALID_SSL_CONF(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_SSL_JSSE_KEYSTORE_LOAD_FAILED(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_UTILS_URI_INVALID_ENCODING(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_WS_NOT_ENABLED() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_BUFFERS_OVERFLOW_EXCEPTION(Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_COMET_ENGINE_FLUSH_INVALID_STAGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_COMET_SELECTOR_CACHE_RESIZE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_GENERAL_CONFIG_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_SECURE_PASSWORD_INITIALIZATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_SSL_IMPLEMENTATION_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_UNKNOWN_CIPHER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_SET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_SET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_FILTERCHAIN_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_DPF_STREAM_ALGORITHM_INIT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_IDLE_THREAD_INTERRUPT(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_DE_REGISTRATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_REGISTRATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_PROCESSOR_TASK_SSL_CERT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_PROCESSOR_TASK_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_PROCESSOR_TASK_TERMINATE_PROCESSES_INTERRUPT() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SCOB_FLUSH_CHANNEL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SCOB_FLUSH_UPSTREAM_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_MBEAN_DEREGISTRATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_MBEAN_REGISTRATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_SOCKET_OPTION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_STATISTICS() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_STOP() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SELECTOR_THREAD_UNKNOWN_THREAD_FACTORY_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_ADD_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_REMOVE_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_DESTROYED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_INITIALIZED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTEXT_LISTENER_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_BOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_UNBOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SEVERE_GRIZZLY_HTTP_PARAMETERS_MAX_COUNT_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_IOSTRATEGY_UNCAUGHT_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_PU_GENERAL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_PU_TLS_PROCESSOR_SKIPPED() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SELECTOR_RUNNER_NOT_IN_STOPPED_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_KEEPALIVE_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_LINGER_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_REUSEADDRESS_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_TCPNODELAY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_TIMEOUT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_STATE_HOLDER_CALLING_CONDITIONLISTENER_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TCPSELECTOR_HANDLER_ACCEPTCHANNEL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_IO_CANCEL_KEY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_CREATE_SELECTOR_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_MISSES_EXCEPTION(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_SELECTOR_FAILURE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_THREADPOOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_PAUSE_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_START_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_STOP_OR_BOUND_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_START_SERVER_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_UNBINDING_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_ABSTRACT_THREAD_POOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_INSTROSPECTION_IAE(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_NO_SELECTORS_AVAILABLE_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REIMBURSEMENT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REMOVAL_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REMOVE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_STATIC_INIT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_TEMPORARY_SELECTOR_RELEASE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_STATE_HOLDER_CONDITION_LISTENER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_WS_MULTIPLE_APPS() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_WS_SELECT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localize(Localizable) - Method in class org.glassfish.grizzly.localization.Localizer
 
Localizer - Class in org.glassfish.grizzly.localization
Localizes the Localizable into a message by using a configured Locale.
Localizer() - Constructor for class org.glassfish.grizzly.localization.Localizer
 
Localizer(Locale) - Constructor for class org.glassfish.grizzly.localization.Localizer
 
lock - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
LogFilter - Class in org.glassfish.grizzly.utils
Simple log Filter
LogFilter() - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
LogFilter(Logger) - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
LogFilter(Logger, Level) - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
logger(Class) - Static method in class org.glassfish.grizzly.Grizzly
 
logger - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
LoggingFormatter - Class in org.glassfish.grizzly.utils
Format the record to include the Thread that logged the record.
LoggingFormatter() - Constructor for class org.glassfish.grizzly.utils.LoggingFormatter
 
LogMessages - Class in org.glassfish.grizzly.localization
Defines string formatting method for each constant in the resource file
LogMessages() - Constructor for class org.glassfish.grizzly.localization.LogMessages
 
lookupCharset(String) - Static method in class org.glassfish.grizzly.utils.Charsets
Lookup a Charset by name.
LZMADecoder - Class in org.glassfish.grizzly.compression.lzma
 
LZMADecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
LZMADecoder.LZMAInputState - Class in org.glassfish.grizzly.compression.lzma
 
LZMADecoder.LZMAInputState() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
LZMAEncoder - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
LZMAEncoder(LZMAEncoder.LZMAProperties) - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
LZMAEncoder.LZMAOutputState - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder.LZMAOutputState() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
LZMAEncoder.LZMAProperties - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder.LZMAProperties() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
LZMAEncoder.LZMAProperties(int, int, int, int, int, int, int) - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
LZMAFilter - Class in org.glassfish.grizzly.compression.lzma
 
LZMAFilter() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAFilter
 

M

main(String[]) - Static method in class org.glassfish.grizzly.Grizzly
 
main(String[]) - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
main(String[]) - Static method in class org.glassfish.grizzly.utils.LoggingFormatter
Example to test the com.glassfish.grizzly.utils.LoggingFormatter You need to include this parameter in the command line -Djava.util.logging.config.file=myfile
makeCancellableFuture(Connection) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
makeIOException(Throwable) - Static method in class org.glassfish.grizzly.utils.Exceptions
Wrap the given Throwable by IOException.
managedWorkerPool - Variable in class org.glassfish.grizzly.AbstractTransport
 
mark() - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's mark at its position.
mark() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
mark() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
mark - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
mark() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
markForRecycle(boolean) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Deprecated.  
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
maxAsyncWriteQueueSize - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
maxBufferSize - Variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
maxPendingBytes - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
maxPendingBytes - Variable in class org.glassfish.grizzly.ssl.SSLFilter
 
maxPoolSize - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
maxQueuedTasks - Variable in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
maxSmallBufferSize - Variable in class org.glassfish.grizzly.memory.ByteBufferManager
 
maxWriteReentrants - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
memoryManager - Variable in class org.glassfish.grizzly.AbstractTransport
Transport MemoryManager
MemoryManager - Class in org.glassfish.grizzly.memory.jmx
MemoryManager JMX object.
MemoryManager(MemoryManager) - Constructor for class org.glassfish.grizzly.memory.jmx.MemoryManager
 
memoryManager - Variable in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
MemoryManager<E extends Buffer> - Interface in org.glassfish.grizzly.memory
MemoryManager, responsible for allocating and releasing memory, required during application runtime.
memoryManager - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
memoryManager - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
MemoryProbe - Interface in org.glassfish.grizzly.memory
MemoryManager monitoring probe.
MemoryProbe.Adapter - Class in org.glassfish.grizzly.memory
MemoryProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
MemoryProbe.Adapter() - Constructor for class org.glassfish.grizzly.memory.MemoryProbe.Adapter
 
MemoryUtils - Class in org.glassfish.grizzly.memory
Class has useful methods to simplify the work with Buffers.
MemoryUtils() - Constructor for class org.glassfish.grizzly.memory.MemoryUtils
 
message - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
MessageCloner<E> - Interface in org.glassfish.grizzly.asyncqueue
Cloner, which will be called by AsyncQueueWriter, when message could not be written directly, and will be added to the queue.
mm - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
mom - Variable in class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
 
MonitoringAware<E> - Interface in org.glassfish.grizzly.monitoring
General interface for the objects, which could be monitored during the lifecycle.
monitoringConfig - Variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
Basic monitoring support.
MonitoringConfig<E> - Interface in org.glassfish.grizzly.monitoring
General monitoring configuration interface.
monitoringConfig - Variable in class org.glassfish.grizzly.nio.NIOConnection
Connection probes
monitoringConfig - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
ThreadPool probes
MonitoringConfigImpl<E> - Class in org.glassfish.grizzly.monitoring
Monitoring configuration.
MonitoringConfigImpl(Class<E>) - Constructor for class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
 
moveBlock() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
movePos() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
movePos() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
multiBufferWindow - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 

N

name - Variable in class org.glassfish.grizzly.AbstractTransport
Transport name
name() - Method in class org.glassfish.grizzly.attributes.Attribute
Return attribute name, which is used as attribute key on non-indexed AttributeHolders.
name2Attribute - Variable in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
NamedAttributeHolder - Class in org.glassfish.grizzly.attributes
AttributeHolder implementation, which doesn't support indexed access to Attributes.
NamedAttributeHolder(AttributeBuilder) - Constructor for class org.glassfish.grizzly.attributes.NamedAttributeHolder
 
NEED_HANDSHAKE_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
NEED_HANDSHAKE_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
needClientAuth - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Require client Authentication.
newBuffer() - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
Construct CompositeBuffer.
newBuffer(MemoryManager) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(MemoryManager, Buffer...) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(MemoryManager, Buffer[], boolean) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(int) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
newBuffer(int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
newBuffer(int) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
newInstance() - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
newInstance() - Static method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
newSelector(SelectorProvider) - Static method in class org.glassfish.grizzly.nio.Selectors
Creates new Selector using passed SelectorProvider.
NextAction - Interface in org.glassfish.grizzly.filterchain
The interface defines the instruction for a FilterChain, how it should continue filter chain execution.
nextFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
nextThreadId() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
NIOChannelDistributor - Interface in org.glassfish.grizzly.nio
 
nioChannelDistributor - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
NIOConnection - Class in org.glassfish.grizzly.nio
Common Connection implementation for Java NIO Connections.
NIOConnection(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.NIOConnection
 
NIOTransport - Class in org.glassfish.grizzly.nio
 
NIOTransport(String) - Constructor for class org.glassfish.grizzly.nio.NIOTransport
 
NIOTransport - Class in org.glassfish.grizzly.nio.transport.jmx
NIO Transport JMX object.
NIOTransport(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
NIOTransportBuilder<T extends NIOTransportBuilder> - Class in org.glassfish.grizzly
This builder is responsible for creating NIOTransport implementations as well as providing basic configuration for IOStrategies and thread pools.
NIOTransportBuilder(Class<? extends NIOTransport>, IOStrategy) - Constructor for class org.glassfish.grizzly.NIOTransportBuilder
Constructs a new NIOTransport using the given transportClass and IOStrategy.
NO_FILTER_INDEX - Static variable in class org.glassfish.grizzly.filterchain.FilterChainContext
 
NOT_LOCALIZABLE - Static variable in interface org.glassfish.grizzly.localization.Localizable
Special constant that represents a message that is not localizable.
NOTIFICATION_CLOSED_COMPLETE - Static variable in class org.glassfish.grizzly.nio.NIOConnection
 
NOTIFICATION_INITIALIZED - Static variable in class org.glassfish.grizzly.nio.NIOConnection
 
notifyAvailable(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyCancel(FutureImpl<R>, CompletionHandler) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler via the cancellation notification.
notifyChangedExcept(Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
 
notifyComplete() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
notifyCompleteAndRecycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
notifyCompleted(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
notifyCompleted(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyCondition(Condition) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyCondition(Condition, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Input
 
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamInput
 
notifyCondition(Condition) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyConditionListeners() - Method in class org.glassfish.grizzly.utils.StateHolder
 
notifyConnectionError(Throwable) - Method in interface org.glassfish.grizzly.Connection
Method gets invoked, when error occur during the Connection lifecycle.
notifyConnectionError(Throwable) - Method in class org.glassfish.grizzly.nio.NIOConnection
Method gets invoked, when error occur during the Connection lifecycle.
notifyDownstream(FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyDownstream(FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyException(ExceptionHandler.Severity, Throwable) - Method in interface org.glassfish.grizzly.utils.ExceptionHandler
 
notifyFailure(Throwable) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
notifyFailure(CompletionHandler<Integer>, Throwable) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
notifyFailure(CompletionHandler<Integer>, Throwable) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyFailure(FutureImpl<R>, CompletionHandler, Throwable) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler using the passed error
notifyHaveResult() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Notify blocked listeners threads about operation completion.
notifyIncomplete() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
notifyIOEventDisabled(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event disabled event.
notifyIOEventEnabled(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event enabled event.
notifyIOEventReady(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event ready event.
notifyProbesAccept(NIOConnection, NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the accept event.
notifyProbesBind(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the bind event.
notifyProbesClose(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the close event.
notifyProbesConfigChanged(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the config changed event.
notifyProbesConnect(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the connect event.
notifyProbesError(NIOConnection, Throwable) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the error.
notifyProbesError(NIOTransport, Throwable) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the error.
notifyProbesPause(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the pause event.
notifyProbesRead(NIOConnection, Buffer, int) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the read event.
notifyProbesResume(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the resume event.
notifyProbesStart(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the start event.
notifyProbesStop(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the stop event.
notifyProbesWrite(NIOConnection, Buffer, long) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the write event.
notifyReady() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
notifyReady() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
notifyResult(FutureImpl<R>, CompletionHandler<R>, R) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler using the passed result object.
notifyTransportError(Throwable) - Method in class org.glassfish.grizzly.nio.NIOTransport
Method gets invoked, when error occur during the Transport lifecycle.
notifyTransportError(Throwable) - Method in interface org.glassfish.grizzly.Transport
Method gets invoked, when error occur during the Transport lifecycle.
notifyUpstream(FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyUpstream(FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyWhenConditionMatchState(Condition, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will match the condition.
notifyWhenStateIsEqual(E, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will be equal to passed one.
notifyWhenStateIsNotEqual(E, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will become not equal to passed one.
notifyWritePossible(Connection, WriteHandler, int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Registers WriteHandler, which will be notified ones Buffer of "size"-bytes can be written.
notifyWritePossible(WriteHandler, int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
notifyWritePossible(Connection, WriteHandler, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Registers WriteHandler, which will be notified ones Buffer of "size"-bytes can be written.
nowPos64 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
NullaryFunction<T> - Interface in org.glassfish.grizzly.attributes
Attribute initializer.

O

ObjectPool<E extends PoolableObject> - Interface in org.glassfish.grizzly.utils
Basic interface for object pool implementations
obtainArrayCopy() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the copy of the underlying array.
obtainContext(Connection) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Creates Context
obtainContext(Connection) - Method in interface org.glassfish.grizzly.Processor
Creates Context
obtainContext(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
obtainCurrentElement() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Get the current processing task, if the current in not set, take the task from the queue.
obtainCurrentElementAndReserve() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Gets the current processing task and reserves its place.
obtainFilterChainContext(Connection) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
obtainFilterChainContext(Connection) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
obtainIndex(Class<E>, int) - Static method in class org.glassfish.grizzly.ThreadCache
 
obtainIndex(String, Class<E>, int) - Static method in class org.glassfish.grizzly.ThreadCache
 
obtainMemoryManager(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
obtainPostponedTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
obtainProcessor(IOEvent, Connection) - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default Processor, which will process Transport Connections I/O events in case, if Connection doesn't have own Processor preferences.
obtainProcessor(IOEvent) - Method in interface org.glassfish.grizzly.Connection
Gets the Processor, which will process Connection I/O event.
obtainProcessor(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
obtainProcessor(IOEvent, Connection) - Method in interface org.glassfish.grizzly.Transport
Gets the default Processor, which will process Transport Connections I/O events in case, if Connection doesn't have own Processor preferences.
obtainProcessorState(Processor, NullaryFunction<E>) - Method in interface org.glassfish.grizzly.Connection
Returns the Processor state associated with this Connection.
obtainProcessorState(Processor, NullaryFunction<E>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
obtainStateObject(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
offer(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Add the new task into the task queue.
offer(Selector) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
offer(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
offer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
offer(E) - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
offerToTaskQueue(NIOConnection, AsyncWriteQueueRecord, TaskQueue<AsyncWriteQueueRecord>) - Static method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
offerToTaskQueue(NIOConnection, AsyncWriteQueueRecord, TaskQueue<AsyncWriteQueueRecord>) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
offset - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
onAccept(Connection, WritableMessage) - Method in interface org.glassfish.grizzly.asyncqueue.PushBackHandler
The method is invoked once message is accepted by Writer.
onAccept() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Method will be called by framework, when async accept will be ready
onAcceptEvent(Connection, Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when server side connection gets accepted.
onAcceptEvent(Connection, Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when server side connection gets accepted.
onAdded(FilterChain) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
onAdded(FilterChain) - Method in interface org.glassfish.grizzly.filterchain.Filter
Method is called, when the Filter has been added to the passed FilterChain.
onAdded(FilterChain) - Method in class org.glassfish.grizzly.utils.LogFilter
 
onAllDataRead() - Method in interface org.glassfish.grizzly.ReadHandler
Invoked when all data for the current request has been read.
onBindEvent(Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when server side connection gets bound.
onBindEvent(Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when server side connection gets bound.
onBufferAllocateEvent(int) - Method in class org.glassfish.grizzly.memory.MemoryProbe.Adapter
Called by MemoryManager, when new buffer gets allocated
onBufferAllocateEvent(int) - Method in interface org.glassfish.grizzly.memory.MemoryProbe
Called by MemoryManager, when new buffer gets allocated
onBufferAllocateFromPoolEvent(int) - Method in class org.glassfish.grizzly.memory.MemoryProbe.Adapter
Called by MemoryManager, when buffer gets allocated from some pool
onBufferAllocateFromPoolEvent(int) - Method in interface org.glassfish.grizzly.memory.MemoryProbe
Called by MemoryManager, when buffer gets allocated from some pool
onBufferReleaseToPoolEvent(int) - Method in class org.glassfish.grizzly.memory.MemoryProbe.Adapter
Called by MemoryManager, when buffer gets releaed into a buffer pool
onBufferReleaseToPoolEvent(int) - Method in interface org.glassfish.grizzly.memory.MemoryProbe
Called by MemoryManager, when buffer gets releaed into a buffer pool
onClose(Connection) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClose() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
onClose(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClose(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClosed(Connection, Connection.CloseType) - Method in interface org.glassfish.grizzly.Connection.CloseListener
 
onClosed() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
onClosed() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
onClosed() - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
onCloseEvent(Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when Connection gets closed.
onCloseEvent(Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when Connection gets closed.
onCloseInputSource() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
onCloseInputSource() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
onCloseInputSource() - Method in class org.glassfish.grizzly.streams.TransformerInput
 
onComplete(Context, Object) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
IOEvent processing completed.
onComplete(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChainContext.CompletionListener
The method is called, when passed FilterChainContext processing is complete.
onComplete(Context, Object) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
IOEvent processing completed.
onConfigChangeEvent(Transport) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when the Transport configuration gets changed.
onConfigChangeEvent(Transport) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when the Transport configuration gets changed.
onConnect() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called, when the connection gets connected.
onConnect() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Method will be called, when the connection gets connected.
onConnectedAsync(TCPNIOConnection, CompletionHandler<Connection>) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
onConnectEvent(Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when client side connection gets connected (opened).
onConnectEvent(Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when client side connection gets connected (opened).
onContextManualIOEventControl(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Processing switched to the manual IOEvent control.
onContextManualIOEventControl(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Processing switched to the manual IOEvent control.
onContextResume(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
IOEvent processing resumed.
onContextResume(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
IOEvent processing resumed.
onContextSuspend(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
IOEvent processing suspended.
onContextSuspend(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
IOEvent processing suspended.
onCopy(FilterChainContext, FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChainContext.CopyListener
The method is called, when passed FilterChainContext is copied.
onDataAvailable() - Method in interface org.glassfish.grizzly.ReadHandler
Invoked when data is available to be read without blocking.
onDeregister(GrizzlyJmxManager) - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
onDeregister(GrizzlyJmxManager) - Method in class org.glassfish.grizzly.monitoring.jmx.JmxObject
Method will be called right after this JmxObject is unregistered by the JMX manager.
onDeregister(GrizzlyJmxManager) - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
onDeregister(GrizzlyJmxManager) - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
Method will be called right after this JmxObject is unregistered by the JMX manager.
onError(Context, Object) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Error occurred during IOEvent processing.
onError(Context, Object) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Error occurred during IOEvent processing.
onError(Throwable) - Method in interface org.glassfish.grizzly.ReadHandler
Invoked when an error occurs processing the request asynchronously.
onError(Throwable) - Method in interface org.glassfish.grizzly.WriteHandler
Invoked when an error occurs processing the request asynchronously.
onErrorEvent(Connection, Throwable) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when error occurs on the Connection.
onErrorEvent(Connection, Throwable) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when error occurs on the Connection.
onErrorEvent(Transport, Throwable) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when error occurs on the Transport.
onErrorEvent(Transport, Throwable) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when error occurs on the Transport.
onFilterChainChanged(FilterChain) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
onFilterChainChanged(FilterChain) - Method in interface org.glassfish.grizzly.filterchain.Filter
Method is called, when the FilterChain this Filter is part of, has been changed.
onFilterChainChanged(FilterChain) - Method in class org.glassfish.grizzly.utils.LogFilter
 
onIOEventDisableEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when IOEvent for the specific Connection gets disabled.
onIOEventDisableEvent(Connection, IOEvent) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when IOEvent for the specific Connection gets disabled.
onIOEventEnableEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when IOEvent for the specific Connection gets enabled.
onIOEventEnableEvent(Connection, IOEvent) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when IOEvent for the specific Connection gets enabled.
onIOEventReadyEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when IOEvent for the specific Connection gets ready.
onIOEventReadyEvent(Connection, IOEvent) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when IOEvent for the specific Connection gets ready.
onKeyDeregistered(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
onKeyDeregistered(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
onKeyRegistered(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
onKeyRegistered(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
onLeave(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Detaching IOEvent processing out of this Context.
onLeave(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Detaching IOEvent processing out of this Context.
onMaxNumberOfThreadsEvent(AbstractThreadPool, int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when the AbstractThreadPool implementation has allocated and is managing a number of threads equal to the maximum limit of the pool.
onMaxNumberOfThreadsEvent(AbstractThreadPool, int) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when the AbstractThreadPool implementation has allocated and is managing a number of threads equal to the maximum limit of the pool.
onMaxNumberOfThreadsReached() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by AbstractThreadPool, when maximum number of worker threads is reached and task will need to wait in task queue, until one of the threads will be able to process it.
onNotRun(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
IOEvent wasn't processed.
onNotRun(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
IOEvent wasn't processed.
onOpenInputSource() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
onOpenInputSource() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
onOpenInputSource() - Method in class org.glassfish.grizzly.streams.TransformerInput
 
onPauseEvent(Transport) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when the Transport gets paused.
onPauseEvent(Transport) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when the Transport gets paused.
onProcessInterest(SelectionKey, int) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
onProcessInterest(SelectionKey, int) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
onPushBack(Connection, WritableMessage, PushBackContext) - Method in interface org.glassfish.grizzly.asyncqueue.PushBackHandler
The method is invoked if message was refused by Writer due to I/O or memory limitations.
onRead(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called, when some data was read on the connection
onRead(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Method will be called, when some data was read on the connection
onReadEvent(Connection, Buffer, int) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when the Connection has read data.
onReadEvent(Connection, Buffer, int) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when the Connection has read data.
onReadFailure(Connection, AsyncReadQueueRecord, IOException) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
onReadyToRead(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
onReadyToRead(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
onReadyToRead(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
onReadyToWrite(NIOConnection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
onReadyToWrite(NIOConnection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
onReadyToWrite(NIOConnection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueWriter
 
onRegister(GrizzlyJmxManager, GmbalMBean) - Method in class org.glassfish.grizzly.memory.jmx.MemoryManager
 
onRegister(GrizzlyJmxManager, GmbalMBean) - Method in class org.glassfish.grizzly.monitoring.jmx.JmxObject
Method will be called right after this JmxObject is registered by the JMX manager.
onRegister(GrizzlyJmxManager, GmbalMBean) - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
onRegister(GrizzlyJmxManager, GmbalMBean) - Method in class org.glassfish.grizzly.threadpool.jmx.ThreadPool
Method will be called right after this JmxObject is registered by the JMX manager.
onRemoved(FilterChain) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
onRemoved(FilterChain) - Method in interface org.glassfish.grizzly.filterchain.Filter
Method is called, when the Filter has been removed from the passed FilterChain.
onRemoved(FilterChain) - Method in class org.glassfish.grizzly.utils.LogFilter
 
onReregister(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Reregister IOEvent interest.
onReregister(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Reregister IOEvent interest.
onRerun(Context, Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Re-run IOEvent processing.
onRerun(Context, Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Re-run IOEvent processing.
onResumeEvent(Transport) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when the Transport gets resumed.
onResumeEvent(Transport) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when the Transport gets resumed.
onSelectorClosed(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
onSelectorClosed(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
onStartEvent(Transport) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when the Transport gets started.
onStartEvent(Transport) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when the Transport gets started.
onStopEvent(Transport) - Method in class org.glassfish.grizzly.TransportProbe.Adapter
Method will be called, when the Transport gets stopped.
onStopEvent(Transport) - Method in interface org.glassfish.grizzly.TransportProbe
Method will be called, when the Transport gets stopped.
onTaskCompletedEvent(Runnable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
This method will be invoked when a the specified Runnable has completed execution.
onTaskCompleteEvent(AbstractThreadPool, Runnable) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when a dequeued task has completed processing.
onTaskCompleteEvent(AbstractThreadPool, Runnable) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when a dequeued task has completed processing.
onTaskDequeued(Runnable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by a thread pool each time a task has been dequeued from a task queue.
onTaskDequeueEvent(AbstractThreadPool, Runnable) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when a task has been pulled from the queue and is about to be processed.
onTaskDequeueEvent(AbstractThreadPool, Runnable) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when a task has been pulled from the queue and is about to be processed.
onTaskQueued(Runnable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by a thread pool each time new task has been queued to a task queue.
onTaskQueueEvent(AbstractThreadPool, Runnable) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when a task has been queued for processing.
onTaskQueueEvent(AbstractThreadPool, Runnable) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when a task has been queued for processing.
onTaskQueueOverflow() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by a thread pool, when new task could not be added to a task queue, because task queue is full.
onTaskQueueOverflowEvent(AbstractThreadPool) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when the task queue of the AbstractThreadPool implementation has exceeded its configured size.
onTaskQueueOverflowEvent(AbstractThreadPool) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when the task queue of the AbstractThreadPool implementation has exceeded its configured size.
onTerminate(Context) - Method in class org.glassfish.grizzly.EmptyIOEventProcessingHandler
Terminate IOEvent processing in this thread, but it's going to be continued later.
onTerminate(Context) - Method in interface org.glassfish.grizzly.IOEventProcessingHandler
Terminate IOEvent processing in this thread, but it's going to be continued later.
onThreadAllocateEvent(AbstractThreadPool, Thread) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when an AbstractThreadPool implementation allocates a new managed Thread.
onThreadAllocateEvent(AbstractThreadPool, Thread) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when an AbstractThreadPool implementation allocates a new managed Thread.
onThreadPoolStartEvent(AbstractThreadPool) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when an AbstractThreadPool implementation starts running.
onThreadPoolStartEvent(AbstractThreadPool) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when an AbstractThreadPool implementation starts running.
onThreadPoolStopEvent(AbstractThreadPool) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when an AbstractThreadPool implementation stops.
onThreadPoolStopEvent(AbstractThreadPool) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when an AbstractThreadPool implementation stops.
onThreadReleaseEvent(AbstractThreadPool, Thread) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
This event may be fired when a thread will no longer be managed by the AbstractThreadPool implementation.
onThreadReleaseEvent(AbstractThreadPool, Thread) - Method in interface org.glassfish.grizzly.threadpool.ThreadPoolProbe
This event may be fired when a thread will no longer be managed by the AbstractThreadPool implementation.
onTimeout(Connection) - Method in interface org.glassfish.grizzly.utils.ActivityCheckFilter.TimeoutHandler
 
onTimeout(Connection) - Method in interface org.glassfish.grizzly.utils.IdleTimeoutFilter.TimeoutHandler
 
onWorkerExit(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by AbstractThreadPool.Worker, when it's completing AbstractThreadPool.Worker.run() method execution, which in most cases means, that ThreadPool's thread will be released.
onWorkerExit(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
onWorkerStarted(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by AbstractThreadPool.Worker, when it's starting AbstractThreadPool.Worker.run() method execution, which means, that ThreadPool's thread is getting active and ready to process tasks.
onWrite(Buffer, long) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called, when some data was written on the connection
onWrite(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Method will be called, when some data was written on the connection
onWriteEvent(Connection, Buffer, long) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when the Connection has written data.
onWriteEvent(Connection, Buffer, long) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when the Connection has written data.
onWriteFailure(Connection, AsyncWriteQueueRecord, Throwable) - Static method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
onWritePossible() - Method in interface org.glassfish.grizzly.WriteHandler
This callback will be invoked when the requirements as dictated by writer are met.
operationCompletionHandler - Variable in class org.glassfish.grizzly.filterchain.FilterChainContext
CompletionHandler, which will be notified, when operation will be complete.
order() - Method in interface org.glassfish.grizzly.Buffer
Retrieves this buffer's byte order.
order(ByteOrder) - Method in interface org.glassfish.grizzly.Buffer
Modifies this buffer's byte order.
order() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
order() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
order - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
order() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
org.glassfish.grizzly - package org.glassfish.grizzly
 
org.glassfish.grizzly.asyncqueue - package org.glassfish.grizzly.asyncqueue
 
org.glassfish.grizzly.attributes - package org.glassfish.grizzly.attributes
 
org.glassfish.grizzly.compression.lzma - package org.glassfish.grizzly.compression.lzma
 
org.glassfish.grizzly.compression.lzma.impl - package org.glassfish.grizzly.compression.lzma.impl
 
org.glassfish.grizzly.compression.lzma.impl.lz - package org.glassfish.grizzly.compression.lzma.impl.lz
 
org.glassfish.grizzly.compression.lzma.impl.rangecoder - package org.glassfish.grizzly.compression.lzma.impl.rangecoder
 
org.glassfish.grizzly.compression.zip - package org.glassfish.grizzly.compression.zip
 
org.glassfish.grizzly.filterchain - package org.glassfish.grizzly.filterchain
 
org.glassfish.grizzly.impl - package org.glassfish.grizzly.impl
 
org.glassfish.grizzly.localization - package org.glassfish.grizzly.localization
 
org.glassfish.grizzly.memory - package org.glassfish.grizzly.memory
 
org.glassfish.grizzly.memory.jmx - package org.glassfish.grizzly.memory.jmx
 
org.glassfish.grizzly.monitoring - package org.glassfish.grizzly.monitoring
 
org.glassfish.grizzly.monitoring.jmx - package org.glassfish.grizzly.monitoring.jmx
 
org.glassfish.grizzly.nio - package org.glassfish.grizzly.nio
 
org.glassfish.grizzly.nio.tmpselectors - package org.glassfish.grizzly.nio.tmpselectors
 
org.glassfish.grizzly.nio.transport - package org.glassfish.grizzly.nio.transport
 
org.glassfish.grizzly.nio.transport.jmx - package org.glassfish.grizzly.nio.transport.jmx
 
org.glassfish.grizzly.ssl - package org.glassfish.grizzly.ssl
 
org.glassfish.grizzly.strategies - package org.glassfish.grizzly.strategies
 
org.glassfish.grizzly.streams - package org.glassfish.grizzly.streams
 
org.glassfish.grizzly.threadpool - package org.glassfish.grizzly.threadpool
 
org.glassfish.grizzly.threadpool.jmx - package org.glassfish.grizzly.threadpool.jmx
 
org.glassfish.grizzly.utils - package org.glassfish.grizzly.utils
 
org.glassfish.grizzly.utils.conditions - package org.glassfish.grizzly.utils.conditions
 
output - Variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
Output - Interface in org.glassfish.grizzly.streams
 
OutWindow - Class in org.glassfish.grizzly.compression.lzma.impl.lz
OutWindow
OutWindow() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 

P

Pair<K,L> - Class in org.glassfish.grizzly.utils
Key : Value pair implementation.
Pair() - Constructor for class org.glassfish.grizzly.utils.Pair
 
Pair(K, L) - Constructor for class org.glassfish.grizzly.utils.Pair
 
parseVersion(String) - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
parseWithLengthPrefix(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
parseWithTerminatingSeq(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
patternFilterChain - Variable in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
pause() - Method in class org.glassfish.grizzly.AbstractTransport
Pauses the transport
pause() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
pause() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
pause() - Method in interface org.glassfish.grizzly.Transport
Pauses the transport
peek(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeHolder, the difference from Attribute.get(org.glassfish.grizzly.attributes.AttributeHolder) is that default value or NullaryFunction won't be invoked.
peek(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeStorage, the difference from Attribute.get(AttributeStorage) is that default value or NullaryFunction won't be invoked.
peek() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
PendingWriteQueueLimitExceededException - Exception in org.glassfish.grizzly
Thrown when an attempt is made to add a AsyncWriteQueueRecord that exceeds the configured maximum queue size.
PendingWriteQueueLimitExceededException() - Constructor for exception org.glassfish.grizzly.PendingWriteQueueLimitExceededException
 
PendingWriteQueueLimitExceededException(String) - Constructor for exception org.glassfish.grizzly.PendingWriteQueueLimitExceededException
 
phrase - Variable in class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
poison - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
poisonAll() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
poisonAll() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
poll() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
poll(long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
poll() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
poll() - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
PoolableObject - Interface in org.glassfish.grizzly.utils
 
poolName - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
PortRange - Class in org.glassfish.grizzly
Immutable class representing a port range.
PortRange(int, int) - Constructor for class org.glassfish.grizzly.PortRange
Creates a port range with the given bounds (both inclusive).
PortRange(int) - Constructor for class org.glassfish.grizzly.PortRange
Creates a port range containing a single port.
pos - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
position() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's position.
position(int) - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's position.
position() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
position(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
position() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
position(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
position() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
position(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
posState - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
postpone() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
postSelect(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
postSelect(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
preClose() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
preConfigure(Connection) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Pre-configures Connection object before actual connecting phase will be started.
preloadAllCharsets() - Static method in class org.glassfish.grizzly.utils.Charsets
Preloads all Charsets available to the JMV, which makes charset searching faster (at the cost of memory).
prepare() - Method in class org.glassfish.grizzly.utils.Pair
 
prepare() - Method in interface org.glassfish.grizzly.utils.PoolableObject
 
prepareDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
prepareDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
prepareRemainder(FilterChainContext, DefaultFilterChain.FiltersState, int, int) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Locates a message remainder in the FilterChain, associated with the Connection and prepares the Context for remainder processing.
prepend(Buffer) - Method in interface org.glassfish.grizzly.Buffer
Prepend data from header.position() to header.limit() to the current buffer.
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
preSelect(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
preSelect(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
prevByte - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
previousFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
priority - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
probe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
probes - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
process(Context) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
process(E) - Method in interface org.glassfish.grizzly.Processor
Method will be called by framework to process some event, which occurred on a connection
process(Context) - Method in class org.glassfish.grizzly.StandaloneProcessor
This method should never be called, because StandaloneProcessor.isInterested(IOEvent) returns false for any IOEvent.
processAsync(Context) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Callback method, which is called async.
processAsync(Context) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Callback method, which is called async.
processAsync(Context) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Callback method, which is called async.
processByte(byte, CompositeBuffer.Setter) - Method in interface org.glassfish.grizzly.memory.CompositeBuffer.BulkOperation
Method is responsible to examine/change one single Buffer's byte.
processingHandler - Variable in class org.glassfish.grizzly.Context
IOEventProcessingHandler is called to notify about IOEvent processing life-cycle events like suspend, resume, complete.
processor(Processor) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processor - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default Processor
processor - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
Processor<E extends Context> - Interface in org.glassfish.grizzly
Processor implementations are responsible for processing I/O events, which occur on connection.
ProcessorExecutor - Class in org.glassfish.grizzly
 
ProcessorExecutor() - Constructor for class org.glassfish.grizzly.ProcessorExecutor
 
ProcessorResult - Class in org.glassfish.grizzly
The interface represents the result of Processor execution.
ProcessorResult.Status - Enum in org.glassfish.grizzly
Enumeration represents the status/code of ProcessorResult.
processorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processorSelector - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default ProcessorSelector
processorSelector - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
ProcessorSelector - Interface in org.glassfish.grizzly
Implementations of the interface will be responsible to find correct Processor, which will process IOEvent, occurred on the Connection
PushBackContext - Class in org.glassfish.grizzly.asyncqueue
Context being passed when Writer refuses to accept passed WritableMessage due to I/O or memory limitations.
PushBackContext(AsyncWriteQueueRecord) - Constructor for class org.glassfish.grizzly.asyncqueue.PushBackContext
 
PushBackHandler - Interface in org.glassfish.grizzly.asyncqueue
Callback handler, which will be called by Grizzly Writer implementation, if message can not be neither written nor added to write queue at the moment due to I/O or memory limitations.
put(byte) - Method in interface org.glassfish.grizzly.Buffer
Relative put method  (optional operation).
put(int, byte) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method  (optional operation).
put(Buffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(Buffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(ByteBuffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(ByteBuffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(byte[]) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(byte[], int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(ByteBuffer, int, int, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(Buffer, int, int, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(byte[], int, int, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(byte) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ThreadCache.CachedTypeIndex, Object) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
 
put(Object) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
 
put(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
put8BitString(String) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put8BitString(String) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put8BitString(String) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put8BitString(String) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putByte(byte) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
putChar(char) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a char value  (optional operation).
putChar(int, char) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a char value  (optional operation).
putChar(char) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putChar(char) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putChar(char) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putDouble(double) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a double value  (optional operation).
putDouble(int, double) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a double value  (optional operation).
putDouble(double) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putDouble(double) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putDouble(double) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putFloat(float) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a float value  (optional operation).
putFloat(int, float) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a float value  (optional operation).
putFloat(float) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putFloat(float) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putFloat(float) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putInt(int) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing an int value  (optional operation).
putInt(int, int) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing an int value  (optional operation).
putInt(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putInt(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putInt(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putLong(long) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a long value  (optional operation).
putLong(int, long) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a long value  (optional operation).
putLong(long) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putLong(long) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putLong(long) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putShort(short) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a short value  (optional operation).
putShort(int, short) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a short value  (optional operation).
putShort(short) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putShort(short) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putShort(short) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putToCache(ThreadCache.CachedTypeIndex<E>, E) - Static method in class org.glassfish.grizzly.ThreadCache
 
putToCache(ThreadCache.CachedTypeIndex<E>, E) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 

Q

queue - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
queueAction(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
queueLimit - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
queueRecord - Variable in class org.glassfish.grizzly.asyncqueue.PushBackContext
 

R

RANDOM - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
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(Connection) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data.
read(Connection, Buffer) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection, CompletionHandler<ReadResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
read() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Performs a blocking read.
read(Connection, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Method reads data to the buffer.
read() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read(CompletionHandler<ReadResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read(Connection, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
read(Connection, 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, Buffer) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
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(Connection, CompletionHandler<ReadResult>) - Method in interface org.glassfish.grizzly.Processor
 
read() - Method in interface org.glassfish.grizzly.Readable
Method reads data.
read(CompletionHandler<ReadResult<M, L>>) - Method in interface org.glassfish.grizzly.Readable
 
read(Connection) - Method in interface org.glassfish.grizzly.Reader
Method reads data.
read(Connection, Buffer) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection, Buffer, CompletionHandler<ReadResult<Buffer, L>>, Interceptor<ReadResult>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection, CompletionHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
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
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
read0(NIOConnection, ReadResult<Buffer, SocketAddress>, Buffer, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
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
 
READ_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
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.
readBufferSize - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default buffer size for read operations
readBufferSize - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
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[], int, int) - 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 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.
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.
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(Connection) - Constructor for class org.glassfish.grizzly.ReadResult
 
ReadResult(Connection, 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.
readTimeoutMillis - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
ReadyFutureImpl<R> - Class in org.glassfish.grizzly.impl
Future implementation with the specific unmodifiable result.
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.
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
 
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
 
rebuildSubTree() - Method in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
reconfigure(ThreadPoolConfig) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
Sets the ThreadPoolConfig
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
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 class org.glassfish.grizzly.attributes.NamedAttributeHolder
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(boolean) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Recycle GrizzlyFuture now.
recycle() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
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
 
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
 
reduceOffsets(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
register(Object, JmxObject, String) - Method in class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
Register Grizzly JmxObject as child of the passed parent object with the specific name.
register() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
registerAtRoot(JmxObject, String) - Method in class org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager
Register Grizzly JmxObject at the root with the passed name.
registerChannel(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectorRunner, SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannel(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
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 interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelAsync(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectorRunner, SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannelAsync(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
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 interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelCompletionHandler - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
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
 
registrationStackTrace - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
release(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
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.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(ByteBufferWrapper) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Lets JVM Garbage collector to release buffer.
release() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
release() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
release(HeapBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Release Buffer.
release(E) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Release Buffer.
release(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
release(AttributeStorage) - Method in interface org.glassfish.grizzly.Transformer
The Transformer has done its work and can release all associated resource.
release() - Method in class org.glassfish.grizzly.utils.Pair
 
release() - Method in interface org.glassfish.grizzly.utils.PoolableObject
 
release(AttributeStorage) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
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
 
remainingCapacity() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
remove(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Remove the task from queue.
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(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(Object) - Method in class org.glassfish.grizzly.utils.ArraySet
remove(T[], Object) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Removes the element from the array.
remove(E) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
remove(Object) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
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.utils.ArraySet
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.
removeAttribute(String) - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Remove a name/value object.
removeCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
Remove the Connection.CloseListener.
removeCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
Remove the Connection.CloseListener.
removeCompletionListener(FilterChainContext.CompletionListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Remove the FilterChainContext.CompletionListener.
removeCopyListener(FilterChainContext.CopyListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Remove the FilterChainContext.CopyListener.
removeMonitoringProbe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Remove the ConnectionProbe.
removeProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Remove the monitoring probes.
removeProbes(E...) - Method in class org.glassfish.grizzly.monitoring.MonitoringConfigImpl
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(SSLEngine, FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
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.
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 - Static variable in interface org.glassfish.grizzly.Interceptor
 
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(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
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
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
restore() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
result(R) - Method in interface org.glassfish.grizzly.impl.FutureImpl
Set the result value and notify about operation completion.
result - Variable in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
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 - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
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.AbstractTransport
Resumes the transport after a pause
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.transport.TCPNIOTransport
 
resume() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
resume(Context) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
resume() - Method in interface org.glassfish.grizzly.Transport
Resumes the transport after a pause
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
Instructs Grizzly to try to resend the message right now.
retryWhenPossible() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Instructs Grizzly to send this message once some resources get released.
reuseAddress - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
The socket reuseAddress
reverseDecode(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseDecode(LZMADecoder.LZMAInputState, short[], int, RangeDecoder, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseEncode(RangeEncoder, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseEncode(short[], int, RangeEncoder, int, int) - Static 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
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeregisterChannelOperation
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeRegisterKeyTask
 
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() - Method in interface org.glassfish.grizzly.nio.SelectorHandler.Task
 
run(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandlerTask
 
run() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
run() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
running - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 

S

SafeFutureImpl<R> - Class in org.glassfish.grizzly.impl
Safe FutureImpl implementation.
SafeFutureImpl() - Constructor for class org.glassfish.grizzly.impl.SafeFutureImpl
Creates SafeFutureImpl
SameThreadIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in a current thread.
saveLastResult(AttributeStorage, TransformationResult<K, L>) - Method in class org.glassfish.grizzly.AbstractTransformer
 
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.ChainProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.DefaultProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
Returns FilterChain instance, if it's interested in processing passed IOEvent, or null otherwise.
select(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
select(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
select(IOEvent, Connection) - Method in interface org.glassfish.grizzly.ProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.StandaloneProcessorSelector
Always return null, which means no Processor was found to process IOEvent.
selectionKey - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
selectionKeyHandler - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
SelectionKeyHandler - Interface in org.glassfish.grizzly.nio
SelectionKeyHandler implementations are responsible for handling SelectionKey life cycle events.
selectionKeyInterest2IoEvent(int) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
selectionKeyInterest2IoEvent(int) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
selectorHandler - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
SelectorHandler - Interface in org.glassfish.grizzly.nio
 
SelectorHandler.Task - Interface in org.glassfish.grizzly.nio
 
SelectorHandlerTask - Interface in org.glassfish.grizzly.nio
Task, which may be registered on SelectorHandler and executed in a Selector thread.
selectorPool - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
selectorProvider - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
selectorRunner - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
SelectorRunner - Class in org.glassfish.grizzly.nio
Class is responsible for processing certain (single) SelectorHandler
selectorRunners - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
selectorRunnersCount - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
Selectors - Class in org.glassfish.grizzly.nio
Utility class for Selector related operations.
Selectors() - Constructor for class org.glassfish.grizzly.nio.Selectors
 
selectTimeout - Variable in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
serverConnections - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
The Server connections.
serverSocketSoTimeout - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
The server socket time out
ServiceConfigurationError - Error in org.glassfish.grizzly.utils
Error thrown when something goes wrong while looking up service providers.
ServiceConfigurationError(String) - Constructor for error org.glassfish.grizzly.utils.ServiceConfigurationError
Constructs a new instance with the specified detail string.
ServiceConfigurationError(Throwable) - Constructor for error org.glassfish.grizzly.utils.ServiceConfigurationError
Constructs a new instance that wraps the specified throwable.
ServiceFinder<T> - Class in org.glassfish.grizzly.utils
A simple service-provider lookup mechanism.
SESSION_ID_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the session id.
set(Connection, Object, R, CompletionHandler) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
set(Connection, WritableMessage, WriteResult, CompletionHandler, Object, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
set(AttributeHolder, T) - Method in class org.glassfish.grizzly.attributes.Attribute
Set attribute value, stored on the AttributeHolder.
set(AttributeStorage, T) - Method in class org.glassfish.grizzly.attributes.Attribute
Set attribute value, stored on the AttributeStorage.
set(int, ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
set(int, Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
set(int, Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
set(byte) - Method in interface org.glassfish.grizzly.memory.CompositeBuffer.Setter
Set the current byte value.
setAddress(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Set address, associated with the current IOEvent processing.
setAlgorithm(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setAlgorithm(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setAllowDirectWrite(boolean) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Set true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
setAttribute(String, Object) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Set a name/value object.
setAttribute(int, Object) - Method in interface org.glassfish.grizzly.attributes.IndexedAttributeAccessor
Internal method for dynamic attribute support.
setAttribute(int, Object) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
Internal method for dynamic attribute support.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Set a name/value object.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.attributes.NamedAttributeHolder
Set a name/value object.
setAttributeBuilder(AttributeBuilder) - Method in class org.glassfish.grizzly.AbstractTransport
Set Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
setAttributeBuilder(AttributeBuilder) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the AttributeBuilder to be used by the created NIOTransport.
setAttributeBuilder(AttributeBuilder) - Method in interface org.glassfish.grizzly.Transport
Set Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
setBuffer(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
setBuffer(Buffer, MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
setChannel(SelectableChannel) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setCharset(Charset) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
setCharset(Charset) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
setCipherConfigured(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setClientMode(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Set SSLEngine to be configured to work in client mode.
setClientSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setClientSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setCompletionHandler(CompletionHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
setConnectCompletionHandler(CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setConnection(Connection) - Method in class org.glassfish.grizzly.Context
Set the processing Connection.
setConnectionForKey(NIOConnection, SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
setConnectionForKey(NIOConnection, SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
setCorePoolSize(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setCrc32(CRC32) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setCrc32(CRC32) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
setCurrentElement(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Set current task element.
setCustomTimeout(Connection, long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
Provides an override mechanism for the default timeout.
setData(Object) - Method in class org.glassfish.grizzly.ProcessorResult
 
setDecoderProperties(byte[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
setDecodeStatus(GZipDecoder.DecodeStatus) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setDeflater(Deflater) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
setDictionarySize(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setDictionarySize(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setDirect(boolean) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Set true, if ByteBufferManager works with direct ByteBuffers, or false otherwise.
setDst(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setDst(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setDstAddress(L) - Method in class org.glassfish.grizzly.WriteResult
Set the destination address, the message was written to.
setEmptyRecord(boolean) - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
setEnabledCipherSuites(String[]) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setEnabledProtocols(String[]) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setEndIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setEndMarkerMode(boolean) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setErrorCode(int) - Method in class org.glassfish.grizzly.TransformationResult
 
setErrorDescription(String) - Method in class org.glassfish.grizzly.TransformationResult
 
setExternalRemainder(I) - Method in class org.glassfish.grizzly.TransformationResult
 
setFilterIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setFirst(K) - Method in class org.glassfish.grizzly.utils.Pair
 
setHeaderFlag(int) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setHeaderParseStateValue(int) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setHeaderWritten(boolean) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setImpl(ThreadPoolConfig) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
setInflater(Inflater) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setInitialized(boolean) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setInitialized(boolean) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setInitialized(boolean) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
setInterested(IOEvent, boolean) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Set the the i/o event, this Processor is interested in
setInterested(IOEvent, boolean) - Method in interface org.glassfish.grizzly.Processor
Set the the i/o event, this Processor is interested in
setInterested(IOEvent, boolean) - Method in class org.glassfish.grizzly.StandaloneProcessor
Method does nothing.
setIoEvent(IOEvent) - Method in class org.glassfish.grizzly.Context
Set the processing IOEvent.
setIOStrategy(IOStrategy) - Method in class org.glassfish.grizzly.AbstractTransport
Set the IOStrategy implementation, which will be used by Transport to process IOEvent.
setIOStrategy(IOStrategy) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Changes the IOStrategy that will be used.
setIOStrategy(IOStrategy) - Method in interface org.glassfish.grizzly.Transport
Set the IOStrategy implementation, which will be used by Transport to process IOEvent.
setKeepAlive(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setKeepAlive(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setKeepAliveTime(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setKernelPool0(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
 
setKernelThreadPool(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
Set a thread pool which will run Transport internal tasks.
setKernelThreadPool(ExecutorService) - Method in interface org.glassfish.grizzly.Transport
Set a thread pool which will run Transport internal tasks.
setKernelThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.AbstractTransport
Set the ThreadPoolConfig to be used by the Transport internal thread pool.
setKernelThreadPoolConfig(ThreadPoolConfig) - Method in interface org.glassfish.grizzly.Transport
Set the ThreadPoolConfig to be used by the Transport internal thread pool.
setKeyManagerFactoryAlgorithm(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the key manager factory algorithm.
setKeyPass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of the key in the key store.
setKeyPass(char[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of the key in the key store.
setKeyStoreFile(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets key store file name, also makes sure that if other key store configuration parameters are not set to set them to default values.
setKeyStorePass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of key store.
setKeyStorePass(char[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of key store.
setKeyStoreProvider(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the key store provider name.
setKeyStoreType(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Type of key store.
setLastResult(TransformationResult<K, L>) - Method in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
setLc(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setLcLpPb(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setLinger(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setLinger(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setLp(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setManualIOEventControl() - Method in class org.glassfish.grizzly.Context
Switches processing to the manual IOEvent control.
setMatchFinder(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setMatchFinder(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setMaxAsyncWriteQueueSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the max size (in bytes) of asynchronous write queue associated with connection.
setMaxAsyncWriteQueueSize(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
Set the max size (in bytes) of asynchronous write queue associated with connection.
setMaxAsyncWriteQueueSizeInBytes(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setMaxAsyncWriteQueueSizeInBytes(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
setMaxPendingBytesPerConnection(int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Configures the maximum number of bytes pending to be written for a particular Connection.
setMaxPendingBytesPerConnection(int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Configures the maximum number of bytes pending to be written for a particular Connection.
setMaxPendingBytesPerConnection(int) - Method in class org.glassfish.grizzly.ssl.SSLFilter
Configures the maximum number of bytes that may be queued to be written for a particular Connection.
setMaxPoolSize(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setMaxWriteReentrants(int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Sets the maximum number of write() method reentrants a thread is allowed to made.
setMaxWriteReentrants(int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Sets the maximum number of write() method reentrants a thread is allowed to made.
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.AbstractTransformer
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.AbstractTransport
Set the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the MemoryManager to be used by the created NIOTransport.
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setMemoryManager(MemoryManager) - Method in interface org.glassfish.grizzly.Transport
Set the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
setMessage(Object) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
setMessage(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Set message object, associated with the current processing.
setMessage(K) - Method in class org.glassfish.grizzly.ReadResult
Set the message, which was read.
setMessage(O) - Method in class org.glassfish.grizzly.TransformationResult
 
setMessage(K) - Method in class org.glassfish.grizzly.WriteResult
Set the message, which was read.
setMessageCloner(MessageCloner) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
setMomentumQueueSize(int) - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
setName(String) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the Transport name.
setName(String) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setName(String) - Method in interface org.glassfish.grizzly.Transport
Sets the Transport name.
setNeedClientAuth(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setNIOChannelDistributor(NIOChannelDistributor) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setNIOChannelDistributor(NIOChannelDistributor) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the NIOChannelDistributor to be used by the created NIOTransport.
setNumFastBytes(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setNumFastBytes(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setOptimizedForMultiplexing(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Configures TCPNIOTransport to be optimized for specific for the connection multiplexing usecase, when different threads will try to write data simultaneously.
setOptimizedForMultiplexing(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setPb(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setPoolName(String) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setPositionLimit(E, int, int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
setPositionLimit(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.BufferArray
 
setPositionLimit(Buffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
setPositionLimit(ByteBuffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
setPositionLimit(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
setPriority(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setProcessingHandler(IOEventProcessingHandler) - Method in class org.glassfish.grizzly.Context
 
setProcessor(Processor) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Set the default Processor to process IOEvent, occurring on connection phase.
setProcessor(Processor) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
setProcessor(Processor) - Method in interface org.glassfish.grizzly.Connection
Sets the default Processor, which will process Connection I/O events.
setProcessor(Processor) - Method in class org.glassfish.grizzly.Context
Set the Processor, which is responsible to process the IOEvent.
setProcessor(Processor) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setProcessor(Processor) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setProcessor(Processor) - Method in interface org.glassfish.grizzly.Transport
Sets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Sets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
setProcessorSelector(ProcessorSelector) - Method in interface org.glassfish.grizzly.Connection
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Connection's Processor is null.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setProcessorSelector(ProcessorSelector) - Method in interface org.glassfish.grizzly.Transport
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
setProtocolConfigured(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setPushBackHandler(PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
setQueue(Queue<Runnable>) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setQueueLimit(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.AbstractTransport
Set the default size of Buffers, which will be allocated for reading data from Transport's Connections.
setReadBufferSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the default size of Buffers, which will be allocated for reading data from Connection.
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setReadBufferSize(int) - Method in interface org.glassfish.grizzly.Transport
Set the default size of Buffers, which will be allocated for reading data from Transport's Connections.
setReader(AsyncQueueReader<L>) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
 
setReadSize(int) - Method in class org.glassfish.grizzly.ReadResult
Set the number of bytes, which were read.
setReadTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Connection
 
setReadTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setResult(R) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Should not be called for ReadyFutureImpl
setResult(E) - Method in interface org.glassfish.grizzly.utils.ResultAware
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
setSecond(L) - Method in class org.glassfish.grizzly.utils.Pair
 
setSecurityProtocol(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the SSLContext protocol.
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setSelectionKeyHandler(SelectionKeyHandler) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectionKeyHandler(SelectionKeyHandler) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectionKeyHandler to be used by the created NIOTransport.
setSelectorHandler(SelectorHandler) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectorHandler(SelectorHandler) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectorHandler to be used by the created NIOTransport.
setSelectorPool(TemporarySelectorPool) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
setSelectorProvider(SelectorProvider) - Method in class org.glassfish.grizzly.nio.NIOTransport
Set the SelectorProvider to be used by this transport.
setSelectorProvider(SelectorProvider) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectorProvider to be used by the created NIOTransport.
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setSelectorRunnersCount(int) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectorThread(boolean) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
setSelectorThread(boolean) - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
setServerConnectionBackLog(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Set the default server connection backlog size.
setServerConnectionBackLog(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setServerSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setServerSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setSize(int) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
setSrc(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setSrc(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setSrcAddress(L) - Method in class org.glassfish.grizzly.ReadResult
Set the source address, the message was read from.
setSSLEngine(AttributeStorage, SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
setStartIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setState(FilterChainContext.Operation, int, DefaultFilterChain.FilterStateElement) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain.FiltersState
 
setState(E) - Method in class org.glassfish.grizzly.utils.StateHolder
Sets current state Current StateHolder locking mode will be used
setStatus(ProcessorResult.Status) - Method in class org.glassfish.grizzly.ProcessorResult
 
setStatus(TransformationResult.Status) - Method in class org.glassfish.grizzly.TransformationResult
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
setTcpNoDelay(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setTcpNoDelay(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setThreadFactory(ThreadFactory) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Set the timeout for StreamWriter I/O operations.
setTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Set the timeout for StreamWriter I/O operations.
setTimeoutMillis(E, long) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
setTrackingThreadCache(boolean) - Static method in class org.glassfish.grizzly.Grizzly
 
setTransactionMonitor(DelayedExecutor) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
setTransactionTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(DelayedExecutor, long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
setTrustManagerFactoryAlgorithm(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the trust manager factory algorithm.
setTrustStoreFile(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets trust store file name, also makes sute that if other trust store configuration parameters are not set to set them to default values.
setTrustStorePass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of trust store.
setTrustStoreProvider(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the trust store provider name.
setTrustStoreType(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Type of trust store.
setType(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
setWantClientAuth(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setWorkerThreadPool(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
Set a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
setWorkerThreadPool(ExecutorService) - Method in interface org.glassfish.grizzly.Transport
Set a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
setWorkerThreadPool0(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
 
setWorkerThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.AbstractTransport
Set the ThreadPoolConfig to be used by the worker thread pool.
setWorkerThreadPoolConfig(ThreadPoolConfig) - Method in interface org.glassfish.grizzly.Transport
Set the ThreadPoolConfig to be used by the worker thread pool.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.AbstractTransport
Set the default size of Buffers, which will be allocated for writing data to Transport's Connections.
setWriteBufferSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the default size of Buffers, which will be allocated for writing data to Connection.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setWriteBufferSize(int) - Method in interface org.glassfish.grizzly.Transport
Set the default size of Buffers, which will be allocated for writing data to Transport's Connections.
setWriter(AsyncQueueWriter<L>) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
 
setWriteTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Connection
 
setWriteTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setWrittenSize(long) - Method in class org.glassfish.grizzly.WriteResult
Set the number of bytes, which were written.
SEVERE_GRIZZLY_COMET_ENGINE_FLUSH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0104: Response resume failed during post-execute of comet task.
SEVERE_GRIZZLY_COMET_ENGINE_INVALID_NOTIFICATION_HANDLER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0103: Invalid NotificationHandler class [{0}].
SEVERE_GRIZZLY_COMET_IO_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0102: I/O error occurred during invocation of {0}.
SEVERE_GRIZZLY_COMETD_ONEVENT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0450: Exception while processing onEvent.
SEVERE_GRIZZLY_CONFIG_SSL_CLASS_LOAD_FAILED_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0054: Unable to load class: {0}.
SEVERE_GRIZZLY_CONFIG_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0055: Can not configure SSLImplementation.
SEVERE_GRIZZLY_HTTP_DPF_PROCESSOR_TASK_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0189: ProcessorTask exception.
SEVERE_GRIZZLY_HTTP_GWS_IO_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0188: I/O error sending 404 to user agent.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_CREATE_REQUEST_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0180: Error creating internal request.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_FILTER_INIT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0182: Error initializing filter [{0}]
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_NON_BLOCKING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0179: Unblocking keep-alive exception.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0174: Error finishing request.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_HEADER_TOO_LARGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0178: Request header is too large.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_URI_TOO_LARGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0177: Request URI is too large.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_RESPONSE_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0175: Error finishing response.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_SERVICE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0176: HTTP Processing error.
SEVERE_GRIZZLY_HTTP_PROCESSOR_TASK_UNKNOWN_FILTER(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0181: Unknown filter: {0}.
SEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_CONTROLER_PROCESS_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0186: Exception during controller processing.
SEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_CONTROLLER_START_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0185: Exception starting the controller.
SEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_HTTP_PROCESSING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0183: Exception during HTTP processing.
SEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_INVALID_THREAD_FACTORY_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0187: Invalid ThreadFactory.
SEVERE_GRIZZLY_HTTP_SELECTOR_THREAD_START() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0184: Exception starting end point.
SEVERE_GRIZZLY_UTILS_LOAD_CLASS_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0559: Unable to load class {0}.
SEVERE_GRIZZLY_UTILS_MAPPER_NO_CONTEXT_FOUND(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0561: No context found: {0}.
SEVERE_GRIZZLY_UTILS_SSL_CERT_TRANSLATION_FAILED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0562: Error translating cert {0}.
SEVERE_GRIZZLY_UTILS_SSL_JSSE_ALIAS_NO_KEY_ENTRY(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0563: Alias name {0} does not identify a key entry.
SEVERE_GRIZZLY_UTILS_SSL_JSSE_INVALID_SSL_CONF(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0565: SSL configuration is invalid due to {0}
SEVERE_GRIZZLY_UTILS_SSL_JSSE_KEYSTORE_LOAD_FAILED(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0564: Failed to load keystore type {0} with path {1} due to {2}.
SEVERE_GRIZZLY_UTILS_URI_INVALID_ENCODING(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0560: Invalid URI encoding; {0}.
SEVERE_GRIZZLY_WS_NOT_ENABLED() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0501: WebSockets are not enabled.
shiftLow() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
shrink() - Method in interface org.glassfish.grizzly.Buffer
Disposes the buffer part, outside [position, limit] interval if possible.
shrink() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
shrink() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
shrink() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
shutdown() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
shutdown() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
shutdownNow() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
shutdownNow() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
SilentConnectionFilter - Class in org.glassfish.grizzly.utils
Filter, which determines silent connections and closes them.
SilentConnectionFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.SilentConnectionFilter
 
SimpleDynamicNIOStrategy - Class in org.glassfish.grizzly.strategies
Simple dynamic strategy, which switches I/O processing strategies, basing on statistics.
simulateIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
simulateIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
size() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Returns the message size.
size() - Method in class org.glassfish.grizzly.ChainProcessorSelector
size() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
size() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
size() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
size() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
size() - Method in interface org.glassfish.grizzly.streams.Input
 
size() - Method in class org.glassfish.grizzly.streams.StreamInput
 
size() - Method in class org.glassfish.grizzly.utils.ArraySet
size() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Returns the number of elements in this queue.
skip(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
skip(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
 
skip(int) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
skip(int) - Method in interface org.glassfish.grizzly.streams.Input
 
skip(int) - Method in class org.glassfish.grizzly.streams.StreamInput
 
skip(int) - Method in interface org.glassfish.grizzly.streams.StreamReader
 
skip(long) - Method in class org.glassfish.grizzly.utils.BufferInputStream
slice() - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer whose content is a shared subsequence of this buffer's content.
slice(int, int) - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer whose content is a shared subsequence of this buffer's content.
slice(ByteBuffer, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Slice ByteBuffer of required size from big chunk.
slice(ByteBuffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Get the ByteBuffer's slice basing on its passed position and limit.
slice() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
slice() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
slice() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
SocketAcceptor - Interface in org.glassfish.grizzly
Common interface for SocketAcceptor implementations.
SocketBinder - Interface in org.glassfish.grizzly
Common API for Socket based Transports, which are able to bind server Socket to specific address and listen for incoming data.
SocketConnectorHandler - Interface in org.glassfish.grizzly
Socket based client side connector.
spaceInBytes() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Returns the number of queued bytes.
split(int) - Method in interface org.glassfish.grizzly.Buffer
Split up the buffer into two parts: [0..splitPosition) and [splitPosition, capacity).
split(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
split(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
split(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Split up the buffer into two parts: [0..splitPosition) and [splitPosition, capacity).
SSL_ENGINE_ATTR_NAME - Static variable in class org.glassfish.grizzly.ssl.SSLUtils
 
SSLCodec - Class in org.glassfish.grizzly.ssl
SSL Codec, which contains SSL encoder and decoder Transformers.
SSLCodec(SSLContextConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLCodec
 
SSLCodec(SSLContext) - Constructor for class org.glassfish.grizzly.ssl.SSLCodec
 
sslContext - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
sslContextConfiguration - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLContextConfigurator - Class in org.glassfish.grizzly.ssl
Utility class, which helps to configure SSLContext.
SSLContextConfigurator() - Constructor for class org.glassfish.grizzly.ssl.SSLContextConfigurator
Default constructor.
SSLContextConfigurator(boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLContextConfigurator
Constructor that allows you creating empty configuration.
SSLDecoderTransformer - Class in org.glassfish.grizzly.ssl
Transformer, which decodes SSL encrypted data, contained in the input Buffer, to the output Buffer.
SSLDecoderTransformer() - Constructor for class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
SSLDecoderTransformer(MemoryManager) - Constructor for class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
SSLEncoderTransformer - Class in org.glassfish.grizzly.ssl
Transformer, which encrypts plain data, contained in the input Buffer, into SSL/TLS data and puts the result to the output Buffer.
SSLEncoderTransformer() - Constructor for class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
SSLEncoderTransformer(MemoryManager) - Constructor for class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
sslEngineAttribute - Static variable in class org.glassfish.grizzly.ssl.SSLUtils
 
SSLEngineConfigurator - Class in org.glassfish.grizzly.ssl
Utility class, which helps to configure SSLEngine.
SSLEngineConfigurator(SSLContext) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContext.
SSLEngineConfigurator(SSLContext, boolean, boolean, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContext, using passed client mode, need/want client auth parameters.
SSLEngineConfigurator(SSLContextConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContextConfigurator.
SSLEngineConfigurator(SSLContextConfigurator, boolean, boolean, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContextConfigurator.
SSLEngineConfigurator(SSLEngineConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLEngineConfigurator() - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLFilter - Class in org.glassfish.grizzly.ssl
SSL Filter to operate with SSL encrypted data.
SSLFilter() - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
 
SSLFilter(SSLEngineConfigurator, SSLEngineConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLFilter(SSLEngineConfigurator, SSLEngineConfigurator, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLFilter.CertificateEvent - Class in org.glassfish.grizzly.ssl
 
SSLFilter.CertificateEvent(boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLFilter.CertificateEvent
 
SSLStreamReader - Class in org.glassfish.grizzly.ssl
SSL aware StreamReader implementation, which work like a wrapper over existing StreamReader.
SSLStreamReader(StreamReader) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamReader
 
SSLStreamWriter - Class in org.glassfish.grizzly.ssl
SSL aware StreamWriter implementation, which work like a wrapper over existing StreamWriter.
SSLStreamWriter(StreamWriter) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter
 
SSLStreamWriter.HandshakeCompletionHandler - Class in org.glassfish.grizzly.ssl
 
SSLStreamWriter.HandshakeCompletionHandler(FutureImpl<SSLEngine>, CompletionHandler<SSLEngine>, SSLEngine) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter.HandshakeCompletionHandler
 
SSLStreamWriter.SSLHandshakeCondition - Class in org.glassfish.grizzly.ssl
 
SSLStreamWriter.SSLHandshakeCondition(StreamReader, StreamWriter, SSLEngineConfigurator, SSLEngine, SSLStreamWriter.HandshakeCompletionHandler) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
SSLSupport - Interface in org.glassfish.grizzly.ssl
SSLSupport Interface for SSL-specific functions
SSLSupport.CipherData - Class in org.glassfish.grizzly.ssl
Simple data class that represents the cipher being used, along with the corresponding effective key size.
SSLSupport.CipherData(String, int) - Constructor for class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
SSLSupportImpl - Class in org.glassfish.grizzly.ssl
 
SSLSupportImpl(Connection) - Constructor for class org.glassfish.grizzly.ssl.SSLSupportImpl
 
SSLUtils - Class in org.glassfish.grizzly.ssl
Utility class, which implements the set of useful SSL related operations.
SSLUtils() - Constructor for class org.glassfish.grizzly.ssl.SSLUtils
 
StandaloneProcessor - Class in org.glassfish.grizzly
Processor, which is not interested in processing I/O events.
StandaloneProcessor() - Constructor for class org.glassfish.grizzly.StandaloneProcessor
 
StandaloneProcessorSelector - Class in org.glassfish.grizzly
ProcessorSelector, which doesn't add any Processor to process occurred IOEvent.
StandaloneProcessorSelector() - Constructor for class org.glassfish.grizzly.StandaloneProcessorSelector
 
start() - Method in class org.glassfish.grizzly.AbstractTransport
Starts the transport
start() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
start() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
start() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
start() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
start() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
start() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
start() - Method in interface org.glassfish.grizzly.Transport
Starts the transport
start() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
startSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
startWorker(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
must hold statelock while calling this method.
startWorker(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
state - Variable in class org.glassfish.grizzly.AbstractTransport
Transport state controller
state - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the current processing task state.
state31 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state311 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state311Distance - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state32 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state321 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state321NumDirectBits - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state32PosSlot - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state3Len - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
stateAttr - Variable in class org.glassfish.grizzly.AbstractTransformer
 
stateful() - Static method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
StateHolder<E> - Class in org.glassfish.grizzly.utils
Class, which holds the state.
StateHolder() - Constructor for class org.glassfish.grizzly.utils.StateHolder
Constructs StateHolder.
StateHolder(E) - Constructor for class org.glassfish.grizzly.utils.StateHolder
Constructs StateHolder.
StateHolder.ConditionElement<E> - Class in org.glassfish.grizzly.utils
 
StateHolder.ConditionElement(Condition, FutureImpl<E>, CompletionHandler<E>) - Constructor for class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
stateInit() - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateIsCharState(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateless() - Static method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
stateLock - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
stateLockCondition - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Wait condition to support awaitTermination
stateUpdateChar(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateMatch(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateRep(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateShortRep(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
staticBitIndex - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticM - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticReverseDecodeMethodState - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticSymbol - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
stop() - Method in class org.glassfish.grizzly.AbstractTransport
Stops the transport and closes all the connections
stop() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
stop() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
stop() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
stop() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
stop() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
stop() - Method in interface org.glassfish.grizzly.Transport
Stops the transport and closes all the connections
stop() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
stopSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
strategy - Variable in class org.glassfish.grizzly.AbstractTransport
Transport strategy
Stream - Interface in org.glassfish.grizzly.streams
Common interface for Stream readers and writers.
StreamDecodeCondition<E> - Class in org.glassfish.grizzly.streams
 
StreamDecodeCondition(StreamReader, Transformer<Stream, E>, ResultAware<E>) - Constructor for class org.glassfish.grizzly.streams.StreamDecodeCondition
 
StreamInput - Class in org.glassfish.grizzly.streams
 
StreamInput(StreamReader) - Constructor for class org.glassfish.grizzly.streams.StreamInput
 
StreamOutput - Class in org.glassfish.grizzly.streams
 
StreamOutput(StreamWriter) - Constructor for class org.glassfish.grizzly.streams.StreamOutput
 
StreamReader - Interface in org.glassfish.grizzly.streams
Interface that defines methods for reading primitive types and arrays of primitive types from a stream.
StreamWriter - Interface in org.glassfish.grizzly.streams
Write the primitive Java types and arrays of primitives to some data sink.
StringDecoder - Class in org.glassfish.grizzly.utils
String decoder, which decodes Buffer to String
StringDecoder() - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(String) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(Charset) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringEncoder - Class in org.glassfish.grizzly.utils
String decoder, which decodes Buffer to String
StringEncoder() - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(String) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(Charset) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringFilter - Class in org.glassfish.grizzly.utils
StringFilter implementation, which performs Buffer <-> String transformation.
StringFilter() - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
StringFilter(Charset) - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
StringFilter(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
stringTerminateBytes - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
stringTerminator - Variable in class org.glassfish.grizzly.utils.StringEncoder
 
subList(int, int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
subList(int, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
suspend() - Method in class org.glassfish.grizzly.Context
Notify Context its processing will be suspended in the current thread.
suspend() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Suspend processing of the current task
switchToNewSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
SyncThreadPool - Class in org.glassfish.grizzly.threadpool
ExecutorService implementation, which function the similar way as former Grizzly 1.x Pipeline based thread pools.
SyncThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.SyncThreadPool
 
SyncThreadPool.SyncThreadWorker - Class in org.glassfish.grizzly.threadpool
 
SyncThreadPool.SyncThreadWorker(boolean) - Constructor for class org.glassfish.grizzly.threadpool.SyncThreadPool.SyncThreadWorker
 

T

t - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
take(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
Take the cached object with the given type index from cache.
take() - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
Take (poll) the object from cache.
take() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
takeBuffer() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
takeBuffer() - Method in interface org.glassfish.grizzly.streams.Input
Takes the Input's Buffer.
takeBuffer() - Method in class org.glassfish.grizzly.streams.StreamInput
 
takeBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
takeBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
takeFromCache(ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Take the cached object with the given type index from cache.
takeFromCache(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
Take the cached object with the given type index from cache.
TaskQueue<E> - Class in org.glassfish.grizzly.asyncqueue
Class represents common implementation of asynchronous processing queue.
TaskQueue(TaskQueue.MutableMaxQueueSize) - Constructor for class org.glassfish.grizzly.asyncqueue.TaskQueue
 
TaskQueue.MutableMaxQueueSize - Interface in org.glassfish.grizzly.asyncqueue
 
TCPNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio.transport
The TCP transport AsyncQueueReader implementation, based on the Java NIO
TCPNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
TCPNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio.transport
The TCP transport AsyncQueueWriter implementation, based on the Java NIO
TCPNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
TCPNIOConnection - Class in org.glassfish.grizzly.nio.transport
Connection implementation for the TCPNIOTransport
TCPNIOConnection(TCPNIOTransport, SelectableChannel) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
TCPNIOConnectorHandler - Class in org.glassfish.grizzly.nio.transport
TCP NIO transport client side ConnectorHandler implementation
TCPNIOConnectorHandler(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
TCPNIOConnectorHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOConnectorHandler.Builder(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
TCPNIOServerConnection - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOServerConnection(TCPNIOTransport, ServerSocketChannel) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler(FutureImpl<Connection>) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
TCPNIOTemporarySelectorReader - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOTemporarySelectorReader(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorReader
 
TCPNIOTemporarySelectorWriter - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOTemporarySelectorWriter(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorWriter
 
TCPNIOTransport - Class in org.glassfish.grizzly.nio.transport.jmx
TCP NIO Transport JMX object.
TCPNIOTransport(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.jmx.TCPNIOTransport
 
TCPNIOTransport - Class in org.glassfish.grizzly.nio.transport
TCP Transport NIO implementation
TCPNIOTransport() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
TCPNIOTransportBuilder - Class in org.glassfish.grizzly.nio.transport
NIOTransportBuilder implementation for TCP.
TCPNIOTransportBuilder(Class<? extends TCPNIOTransport>, IOStrategy) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
TCPNIOTransportFilter - Class in org.glassfish.grizzly.nio.transport
The TCPNIOTransport's transport Filter implementation
tcpTransport - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
TemporarySelectorIO - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorIO(Reader<SocketAddress>, Writer<SocketAddress>) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
TemporarySelectorIO(Reader<SocketAddress>, Writer<SocketAddress>, TemporarySelectorPool) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
temporarySelectorIO - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Server socket backlog.
TemporarySelectorPool - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorPool(SelectorProvider) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
TemporarySelectorPool(SelectorProvider, int) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
TemporarySelectorReader - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorReader(TemporarySelectorsEnabledTransport) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
TemporarySelectorsEnabledTransport - Interface in org.glassfish.grizzly.nio.tmpselectors
Common interface for Transports, which will use temporary selectors technics
TemporarySelectorWriter - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorWriter(TemporarySelectorsEnabledTransport) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
ThreadCache - Class in org.glassfish.grizzly
 
ThreadCache() - Constructor for class org.glassfish.grizzly.ThreadCache
 
ThreadCache.CachedTypeIndex<E> - Class in org.glassfish.grizzly
 
ThreadCache.CachedTypeIndex(int, String, Class<E>, int) - Constructor for class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
ThreadCache.ObjectCache - Class in org.glassfish.grizzly
 
ThreadCache.ObjectCache() - Constructor for class org.glassfish.grizzly.ThreadCache.ObjectCache
 
ThreadCache.ObjectCacheElement - Class in org.glassfish.grizzly
 
ThreadCache.ObjectCacheElement(int) - Constructor for class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
 
threadFactory - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
ThreadLocalPool<E> - Interface in org.glassfish.grizzly.memory
TODO Documentation
ThreadLocalPoolProvider - Interface in org.glassfish.grizzly.memory
This interface may be implemented by custom MemoryManager implementations in order to provide per-thread memory management.
ThreadPool - Class in org.glassfish.grizzly.threadpool.jmx
JMX managed object for Grizzly thread pool implementations.
ThreadPool(AbstractThreadPool) - Constructor for class org.glassfish.grizzly.threadpool.jmx.ThreadPool
 
ThreadPoolConfig - Class in org.glassfish.grizzly.threadpool
 
ThreadPoolConfig(String, int, int, Queue<Runnable>, int, long, TimeUnit, ThreadFactory, int, MemoryManager, DelayedExecutor, long) - Constructor for class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
ThreadPoolConfig(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
threadPoolMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Thread pool probes
threadPoolMonitoringConfig - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Thread pool probes
ThreadPoolProbe - Interface in org.glassfish.grizzly.threadpool
Monitoring probe providing callbacks that may be invoked by Grizzly AbstractThreadPool implementations.
ThreadPoolProbe.Adapter - Class in org.glassfish.grizzly.threadpool
ThreadPoolProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
ThreadPoolProbe.Adapter() - Constructor for class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
 
toAdaptedCompletionHandler(FutureImpl<A>, GenericAdapter<B, A>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl.
toAdaptedCompletionHandler(FutureImpl<A>, CompletionHandler<A>, GenericAdapter<B, A>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl and CompletionHandler.
toArray() - Method in class org.glassfish.grizzly.ChainProcessorSelector
toArray(T[]) - Method in class org.glassfish.grizzly.ChainProcessorSelector
toArray() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
toArray(T[]) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
toArray() - Method in class org.glassfish.grizzly.utils.ArraySet
toArray(K[]) - Method in class org.glassfish.grizzly.utils.ArraySet
toArray() - Method in class org.glassfish.grizzly.utils.ServiceFinder
Returns discovered objects all at once.
toBufferArray() - Method in interface org.glassfish.grizzly.Buffer
Returns a new BufferArray instance with this Buffer added as an element to the BufferArray.
toBufferArray(BufferArray) - Method in interface org.glassfish.grizzly.Buffer
Returns the specified BufferArray after adding this Buffer.
toBufferArray(int, int) - Method in interface org.glassfish.grizzly.Buffer
Updates this Buffer's position and limit and adds it to a new BufferArray instance.
toBufferArray(BufferArray, int, int) - Method in interface org.glassfish.grizzly.Buffer
Updates this Buffer's position and limit and adds it to the specified BufferArray.
toBufferArray() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toBufferArray() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBuffer() - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer whose content is a shared subsequence of this buffer's content.
toByteBuffer(int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer whose content is a shared subsequence of this buffer's content.
toByteBuffer() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBuffer() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBuffer0(int, int, boolean) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBufferArray() - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and adds the result to the provided ByteBufferArray.
toByteBufferArray(int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray, int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and adds the result to the provided ByteBufferArray.
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toCompletionHandler(FutureImpl<R>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl.
toCompletionHandler(FutureImpl<R>, CompletionHandler<R>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl and CompletionHandler objects.
toProcessorResult() - Method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
 
toString() - Method in class org.glassfish.grizzly.attributes.Attribute
 
toString() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
toString() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toString() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toString() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toString() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
toString() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
toString() - Method in class org.glassfish.grizzly.PortRange
 
toString() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
toString() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
toString() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
toString() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
toString() - Method in class org.glassfish.grizzly.TransformationResult
 
toString() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
toString() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
toString() - Method in class org.glassfish.grizzly.utils.Pair
 
toStringContent() - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer content as String, using default Charset
toStringContent(Charset) - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer content as String
toStringContent(Charset, int, int) - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer's chunk content as String
toStringContent(ByteBuffer, Charset, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
toStringContent() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
transactionExpirationTime - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
transactionMonitor - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
transactionTimeoutMillis - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
transactionTimeoutMillis - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
transfer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
transfer(E) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Inserts the specified element into this queue, waiting if necessary for space to become available and the element to be dequeued by a consumer invoking take or poll.
TransferQueue<E> - Interface in org.glassfish.grizzly.utils
A BlockingQueue in which producers may wait for consumers to receive elements.
transform(AttributeStorage, K) - Method in class org.glassfish.grizzly.AbstractTransformer
 
transform(AttributeStorage, K) - Method in interface org.glassfish.grizzly.Transformer
Transforms an input data to some custom representation.
TransformationException - Exception in org.glassfish.grizzly
Describes the problem, occured during original message transformation.
TransformationException() - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(String) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(Throwable) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(String, Throwable) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationResult<I,O> - Class in org.glassfish.grizzly
Represents the result of message encoding/decoding.
TransformationResult() - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult(TransformationResult.Status, O, I) - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult(int, String) - Constructor for class org.glassfish.grizzly.TransformationResult
Creates error transformation result with specific code and description.
TransformationResult(TransformationResult.Status, O, I, int, String) - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult.Status - Enum in org.glassfish.grizzly
 
transformer - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
transformer - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
Transformer<K,L> - Interface in org.glassfish.grizzly
Transformer interface, which knows how to transform the original data to some custom representation.
TransformerInput - Class in org.glassfish.grizzly.streams
 
TransformerInput(Transformer<Buffer, Buffer>, Input, Connection) - Constructor for class org.glassfish.grizzly.streams.TransformerInput
 
TransformerInput(Transformer<Buffer, Buffer>, Input, MemoryManager, AttributeStorage) - Constructor for class org.glassfish.grizzly.streams.TransformerInput
 
TransformerInput.TransformerCompletionHandler - Class in org.glassfish.grizzly.streams
 
TransformerInput.TransformerCompletionHandler() - Constructor for class org.glassfish.grizzly.streams.TransformerInput.TransformerCompletionHandler
 
TransformerInput.TransformerCondition - Class in org.glassfish.grizzly.streams
 
TransformerInput.TransformerCondition() - Constructor for class org.glassfish.grizzly.streams.TransformerInput.TransformerCondition
 
TransformerOutput - Class in org.glassfish.grizzly.streams
 
TransformerOutput(Transformer<Buffer, Buffer>, Output, Connection) - Constructor for class org.glassfish.grizzly.streams.TransformerOutput
 
TransformerOutput(Transformer<Buffer, Buffer>, Output, MemoryManager, AttributeStorage) - Constructor for class org.glassfish.grizzly.streams.TransformerOutput
 
TransformerStreamReader - Class in org.glassfish.grizzly.streams
 
TransformerStreamReader(StreamReader, Transformer<Buffer, Buffer>) - Constructor for class org.glassfish.grizzly.streams.TransformerStreamReader
 
TransformerStreamWriter - Class in org.glassfish.grizzly.streams
 
TransformerStreamWriter(StreamWriter, Transformer<Buffer, Buffer>) - Constructor for class org.glassfish.grizzly.streams.TransformerStreamWriter
 
transformImpl(AttributeStorage, K) - Method in class org.glassfish.grizzly.AbstractTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
transformImpl(AttributeStorage, String) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
transport - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
transport - Variable in class org.glassfish.grizzly.DefaultProcessorSelector
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
transport - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
transport - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
transport - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
transport - Variable in class org.glassfish.grizzly.nio.transport.jmx.NIOTransport
 
transport - Variable in class org.glassfish.grizzly.NIOTransportBuilder
The NIOTransport implementation.
Transport - Interface in org.glassfish.grizzly
Transport interface describes the transport unit used in Grizzly.
Transport.State - Enum in org.glassfish.grizzly
 
TransportFilter - Class in org.glassfish.grizzly.filterchain
Transport Filter implementation, which should work with any Transport.
TransportFilter() - Constructor for class org.glassfish.grizzly.filterchain.TransportFilter
Create TransportFilter.
TransportFilter.FlushEvent - Class in org.glassfish.grizzly.filterchain
 
transportMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Transport probes
TransportProbe - Interface in org.glassfish.grizzly
Monitoring probe providing callbacks that may be invoked by Grizzly Transport implementations.
TransportProbe.Adapter - Class in org.glassfish.grizzly
TransportProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
TransportProbe.Adapter() - Constructor for class org.glassfish.grizzly.TransportProbe.Adapter
 
trim() - Method in interface org.glassfish.grizzly.Buffer
Trim the buffer by reducing capacity to position, if possible.
trim() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
trim() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
trim() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
TRUST_FACTORY_MANAGER_ALGORITHM - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_FILE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_PASSWORD - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_PROVIDER - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_TYPE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
tryDispose() - Method in interface org.glassfish.grizzly.Buffer
Try to dispose Buffer if it's allowed.
tryDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
tryDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
tryDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
tryTransfer(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
tryTransfer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
tryTransfer(E) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Transfers the specified element if there exists a consumer already waiting to receive it, otherwise returning false without enqueuing the element.
tryTransfer(E, long, TimeUnit) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available and the element to be dequeued by a consumer invoking take or poll.
type() - Method in interface org.glassfish.grizzly.filterchain.FilterChainEvent
 
type() - Method in interface org.glassfish.grizzly.filterchain.NextAction
Get NextAction type
TYPE - Static variable in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
type() - Method in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
type() - Method in class org.glassfish.grizzly.ssl.SSLFilter.CertificateEvent
 

U

UDPNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio.transport
The UDP transport AsyncQueueReader implementation, based on the Java NIO
UDPNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
UDPNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio.transport
The UDP transport AsyncQueueWriter implementation, based on the Java NIO
UDPNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueWriter
 
UDPNIOConnection - Class in org.glassfish.grizzly.nio.transport
Connection implementation for the UDPNIOTransport
UDPNIOConnection(UDPNIOTransport, DatagramChannel) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
UDPNIOConnectorHandler - Class in org.glassfish.grizzly.nio.transport
UDP NIO transport client side ConnectorHandler implementation
UDPNIOConnectorHandler(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
UDPNIOConnectorHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOConnectorHandler.Builder(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
UDPNIOServerConnection - Class in org.glassfish.grizzly.nio.transport
Server Connection implementation for the UDPNIOTransport
UDPNIOServerConnection(UDPNIOTransport, DatagramChannel) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
UDPNIOTemporarySelectorReader - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTemporarySelectorReader(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorReader
 
UDPNIOTemporarySelectorWriter - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTemporarySelectorWriter(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorWriter
 
UDPNIOTransport - Class in org.glassfish.grizzly.nio.transport.jmx
UDP NIO Transport JMX object.
UDPNIOTransport(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.jmx.UDPNIOTransport
 
UDPNIOTransport - Class in org.glassfish.grizzly.nio.transport
UDP NIO transport implementation
UDPNIOTransport() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
UDPNIOTransport(String) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
UDPNIOTransport.RegisterChannelCompletionHandler - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTransport.RegisterChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport.RegisterChannelCompletionHandler
 
UDPNIOTransport.TransportConnectorHandler - Class in org.glassfish.grizzly.nio.transport
Transport default UDPNIOConnectorHandler.
UDPNIOTransport.TransportConnectorHandler() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
UDPNIOTransportBuilder - Class in org.glassfish.grizzly.nio.transport
NIOTransportBuilder implementation for UDP.
UDPNIOTransportBuilder(Class<? extends UDPNIOTransport>, IOStrategy) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
UDPNIOTransportFilter - Class in org.glassfish.grizzly.nio.transport
The UDPNIOTransport's transport Filter implementation
udpTransport - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Unbinds bound Transport connection.
unbind(CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Unbinds bound Transport connection.
unbind(Connection) - Method in interface org.glassfish.grizzly.SocketBinder
Unbinds bound Transport connection.
unbindAll() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
unbindAll() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
unbindAll() - Method in interface org.glassfish.grizzly.SocketBinder
Unbinds all bound Transport connections.
uncaughtException(Thread, Throwable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
underlying() - Method in interface org.glassfish.grizzly.Buffer
Return the underlying buffer
underlying() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
underlying() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
underlying() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
underlying() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
underlyingInput - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
underlyingOutput - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
UNLIMITED_SIZE - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Constant set via AsyncQueueWriter.setMaxPendingBytesPerConnection(int) means the async write queue size is unlimited.
UNLIMITED_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
UNLIMITED_TRANSACTION_TIMEOUT - Static variable in interface org.glassfish.grizzly.threadpool.WorkerThread
 
UnsafeFutureImpl<R> - Class in org.glassfish.grizzly.impl
Simple thread-unsafe Future implementation.
UNSET_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.DelayedExecutor
 
UNSET_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
update(byte[], int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
update(byte[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
updateByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
updated(E) - Method in interface org.glassfish.grizzly.CompletionHandler
The callback method may be called, when there is some progress in operation execution, but it is still not completed
updated(E) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The callback method may be called, when there is some progress in operation execution, but it is still not completed
updated(Object) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
updated(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
UTF8_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
 
Utils - Class in org.glassfish.grizzly.utils
Class contains set of useful operations commonly used in the framework
Utils() - Constructor for class org.glassfish.grizzly.utils.Utils
 

V

validateConfiguration() - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Validates SSLContextConfigurator configuration.
validateConfiguration(boolean) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Validates SSLContextConfigurator configuration.
validateNewPoolSize(int, int) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
valueOf(String) - Static method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.compression.lzma.impl.Decoder.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.compression.zip.GZipDecoder.DecodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.Connection.CloseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.DefaultFilterChain.FILTER_STATE_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.IOEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.glassfish.grizzly.PortRange
Parse a port range.
valueOf(String) - Static method in enum org.glassfish.grizzly.ProcessorResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.TransformationResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.Transport.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.utils.ExceptionHandler.Severity
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.compression.lzma.impl.Decoder.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.compression.zip.GZipDecoder.DecodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.Connection.CloseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.DefaultFilterChain.FILTER_STATE_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.IOEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.ProcessorResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.TransformationResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.Transport.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.utils.ExceptionHandler.Severity
Returns an array containing the constants of this enum type, in the order they are declared.
visible - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 

W

waitNIOFuture(FutureImpl<Connection>, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
waitNIOFuture(FutureImpl<Connection>, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
wakeupSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
wantClientAuth - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
True when requesting authentication.
wantReset(int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
WARNING_GRIZZLY_BUFFERS_OVERFLOW_EXCEPTION(Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0012: BufferOverflow srcBuffer={0} srcOffset={1} length={2} dstBuffer={3}
WARNING_GRIZZLY_COMET_ENGINE_FLUSH_INVALID_STAGE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0101: Post execution of CometTask invoke during the wrong stage.
WARNING_GRIZZLY_COMET_SELECTOR_CACHE_RESIZE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0100: Unable to re-size selector cache.
WARNING_GRIZZLY_CONFIG_SSL_GENERAL_CONFIG_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0050: SSL support could not be configured!
WARNING_GRIZZLY_CONFIG_SSL_SECURE_PASSWORD_INITIALIZATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0051: Secure password provider could not be initialized: {0}.
WARNING_GRIZZLY_CONFIG_SSL_SSL_IMPLEMENTATION_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0052: Unable to load SSLImplementation: {0}.
WARNING_GRIZZLY_CONFIG_SSL_UNKNOWN_CIPHER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0053: Unrecognized cipher [{0}].
WARNING_GRIZZLY_CONNECTION_SET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0016: Error setting read buffer size
WARNING_GRIZZLY_CONNECTION_SET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0017: Error setting write buffer size
WARNING_GRIZZLY_FILTERCHAIN_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0013: Exception during FilterChain execution
WARNING_GRIZZLY_HTTP_DPF_STREAM_ALGORITHM_INIT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0158: Unable to instantiate Algorithm: {0}.
WARNING_GRIZZLY_HTTP_IDLE_THREAD_INTERRUPT(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0159: Interrupting idle Thread: {0}.
WARNING_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_DE_REGISTRATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0164: Error attempting to deregister request.
WARNING_GRIZZLY_HTTP_PROCESSOR_TASK_REQUEST_REGISTRATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0163: Error registering request.
WARNING_GRIZZLY_HTTP_PROCESSOR_TASK_SSL_CERT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0162: Exception getting SSL certificate.
WARNING_GRIZZLY_HTTP_PROCESSOR_TASK_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0161: Exception getting SSL attributes.
WARNING_GRIZZLY_HTTP_PROCESSOR_TASK_TERMINATE_PROCESSES_INTERRUPT() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0160: Terminate process interrupted.
WARNING_GRIZZLY_HTTP_SCOB_FLUSH_CHANNEL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0170: Async write is enabled, but AsyncWriter is null.
WARNING_GRIZZLY_HTTP_SCOB_FLUSH_UPSTREAM_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0171: Exception discarding upstream bytes.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_MBEAN_DEREGISTRATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0169: Exception when de-registering http-listener [{0}] mbeans.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_MBEAN_REGISTRATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0168: Exception when registering http-listener [{0}] mbeans.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_SOCKET_OPTION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0167: {0} exception.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_STATISTICS() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0165: Statistics could be enabled.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_STOP() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0166: Exception stopping end point.
WARNING_GRIZZLY_HTTP_SELECTOR_THREAD_UNKNOWN_THREAD_FACTORY_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0172: Cannot guess which ThreadFactory the ExecutorService is using.
WARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_ADD_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0302: Exception invoking attributeAdded() or attributeReplaced() on {0}: {1}.
WARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_REMOVE_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0303: Exception invoking attributeRemoved() on {0}: {1}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_DESTROYED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0301: Exception invoking {0}() on {1}: {2}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_INITIALIZED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0300: Exception invoking {0}() on {1}: {2}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTEXT_LISTENER_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0306: Unable to load listener: {0}.
WARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_BOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0305: Exception invoking valueBound() on HttpSessionBindingListener {0}.
WARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_UNBOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0304: Exception invoking valueUnbound() on HttpSessionBindingListener {0}.
WARNING_GRIZZLY_HTTP_SEVERE_GRIZZLY_HTTP_PARAMETERS_MAX_COUNT_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0173: More than the maximum number of request parameters (GET plus POST) for a single request ([{0}]) were detected.
WARNING_GRIZZLY_IOSTRATEGY_UNCAUGHT_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0010: Uncaught exception:
WARNING_GRIZZLY_PU_GENERAL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0400: PortUnification exception.
WARNING_GRIZZLY_PU_TLS_PROCESSOR_SKIPPED() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0401: Grizzly Port unification warning.
WARNING_GRIZZLY_SELECTOR_RUNNER_NOT_IN_STOPPED_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0014: SelectorRunner is not in the stopped state!
WARNING_GRIZZLY_SOCKET_KEEPALIVE_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0005: Can not set SO_KEEPALIVE to {0}
WARNING_GRIZZLY_SOCKET_LINGER_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0003: Can not set SO_LINGER to {0}
WARNING_GRIZZLY_SOCKET_REUSEADDRESS_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0006: Can not set SO_REUSEADDR to {0}
WARNING_GRIZZLY_SOCKET_TCPNODELAY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0004: Can not set TCP_NODELAY to {0}
WARNING_GRIZZLY_SOCKET_TIMEOUT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0007: Can not set SO_TIMEOUT to {0}
WARNING_GRIZZLY_STATE_HOLDER_CALLING_CONDITIONLISTENER_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0015: Error calling ConditionListener
WARNING_GRIZZLY_TCPSELECTOR_HANDLER_ACCEPTCHANNEL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0008: Exception accepting channel
WARNING_GRIZZLY_TEMPORARY_SELECTOR_IO_CANCEL_KEY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0023: Unexpected exception, when canceling the SelectionKey: {0}
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_CREATE_SELECTOR_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0024: SelectorFactory.
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_MISSES_EXCEPTION(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0025: SelectorFactory.
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_SELECTOR_FAILURE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0026: Temporary Selector failure.
WARNING_GRIZZLY_THREADPOOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0011: Uncaught exception on thread {0}
WARNING_GRIZZLY_TRANSPORT_NOT_PAUSE_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0020: Transport is not in PAUSE state!
WARNING_GRIZZLY_TRANSPORT_NOT_START_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0019: Transport is not in START state!
WARNING_GRIZZLY_TRANSPORT_NOT_STOP_OR_BOUND_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0018: Transport is not in STOP or BOUND state!
WARNING_GRIZZLY_TRANSPORT_START_SERVER_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0021: Exception occurred when starting server connection {0}
WARNING_GRIZZLY_TRANSPORT_UNBINDING_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0022: Error unbinding connection {0}
WARNING_GRIZZLY_UTILS_ABSTRACT_THREAD_POOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0550: Uncaught thread exception.
WARNING_GRIZZLY_UTILS_INSTROSPECTION_IAE(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0551: IllegalArgumentException {0} {1} {2}.
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_NO_SELECTORS_AVAILABLE_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0554: No Selectors available.
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REIMBURSEMENT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0556: Problematic Selector could not be reimbursed!
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REMOVAL_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0552: Attempt made to remove too many selectors: {0} >= {1}.
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_SELECTOR_REMOVE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY00557: SelectorFactory cache could not remove the desired number, too few selectors in cache.
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_STATIC_INIT_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0553: Static initialization of SelectorFactory failed.
WARNING_GRIZZLY_UTILS_SELECTOR_FACTORY_TEMPORARY_SELECTOR_RELEASE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0555: Unexpected problem when releasing temporary Selector.
WARNING_GRIZZLY_UTILS_STATE_HOLDER_CONDITION_LISTENER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0558: Error calling ConditionListener.
WARNING_GRIZZLY_WS_MULTIPLE_APPS() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0502: Multiple applications are registered for this request.
WARNING_GRIZZLY_WS_SELECT_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0500: Exception processing select(): {0}.
wasSuspended - Variable in class org.glassfish.grizzly.Context
true if this IOEvent processing was suspended during its processing, or false otherwise.
wasSuspended() - Method in class org.glassfish.grizzly.Context
 
willAllocateDirect(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willAllocateDirect(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willAllocateDirect(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
workerPoolConfig - Variable in class org.glassfish.grizzly.AbstractTransport
 
workers - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
WorkerThread - Interface in org.glassfish.grizzly.threadpool
Interface, which Grizzly thread pool threads should implement.
WorkerThreadIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in worker thread.
workerThreadPool - Variable in class org.glassfish.grizzly.AbstractTransport
Worker thread pool
WorkerThreadPoolConfigProducer - Interface in org.glassfish.grizzly.strategies
Strategy implementations may implement this interface to signify they have certain thread pool configuration requirements that could be used when building the runtime.
workQueue - Variable in class org.glassfish.grizzly.threadpool.FixedThreadPool
 
wrap(MemoryManager, String) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the String.
wrap(MemoryManager, String, Charset) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the String with the specific Charset.
wrap(MemoryManager, byte[]) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the byte array.
wrap(MemoryManager, byte[], int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(MemoryManager, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Static method in class org.glassfish.grizzly.memory.HeapBuffer
 
wrap(byte[], int, int) - Static method in class org.glassfish.grizzly.memory.HeapBuffer
 
wrap(byte[]) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the ByteBuffer.
wrapByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
wrapByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
WrapperAware - Interface in org.glassfish.grizzly.memory
MemoryManagers, which implement this interface, are able to convert frequently used Java buffer types to Grizzly Buffer.
Writable<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to write data from a Buffer.
WritableMessage - Interface in org.glassfish.grizzly.asyncqueue
Common interface for entities that may be written to a Channel.
write(Connection, WritableMessage) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage.
write(Connection, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage.
write(Connection, L, WritableMessage) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage to the specific address.
write(Connection, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage to the specific address.
write(Connection, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler, MessageCloner<WritableMessage>) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Method writes the Buffer to the specific address.
write(Connection, Object, Object, CompletionHandler, PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
write(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, CompletionHandler<WriteResult>, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, MessageCloner) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, MessageCloner, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Connection, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
write(Connection, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler, MessageCloner<WritableMessage>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Method writes the Buffer to the specific address.
write(M) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(M, CompletionHandler<WriteResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(M, CompletionHandler<WriteResult<M, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(SocketAddress, M, CompletionHandler<WriteResult<M, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(Connection, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Method writes the WritableMessage to the specific address.
write(Connection, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Method writes the WritableMessage to the specific address.
write(Connection, WritableMessage) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
write(Connection, WritableMessage, WriteResult) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
write(UDPNIOConnection, SocketAddress, WritableMessage) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
write(UDPNIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
write(Connection, Object, Object, CompletionHandler<WriteResult>, PushBackHandler) - Method in interface org.glassfish.grizzly.Processor
 
write(Connection, Object, Object, CompletionHandler, PushBackHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
write(byte) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
write(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
write(byte) - Method in interface org.glassfish.grizzly.streams.Output
 
write(Buffer) - Method in interface org.glassfish.grizzly.streams.Output
 
write(byte) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
write(Buffer) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
write(int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(byte[]) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(byte[], int, int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(M) - Method in interface org.glassfish.grizzly.Writable
Method writes the buffer.
write(M, CompletionHandler<WriteResult<M, L>>) - Method in interface org.glassfish.grizzly.Writable
Method writes the buffer.
write(M, CompletionHandler<WriteResult<M, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writable
Method writes the buffer.
write(L, M, CompletionHandler<WriteResult<M, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writable
Method writes the buffer to the specific address.
write(Connection, WritableMessage) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage.
write(Connection, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage.
write(Connection, L, WritableMessage) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write(Connection, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write(Connection, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
write0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Flush the buffer by looping until the Buffer is empty
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueWriter
 
writeBoolean(boolean) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the boolean value to the StreamWriter.
writeBoolean(boolean) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the boolean value to the StreamWriter.
writeBooleanArray(boolean[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of boolean values to the StreamWriter.
writeBooleanArray(boolean[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of boolean values to the StreamWriter.
writeBuffer(Buffer) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the Buffer to the StreamWriter.
writeBuffer(Buffer) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the Buffer to the StreamWriter.
writeBufferSize - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default buffer size for write operations
writeBufferSize - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
writeByte(byte) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the byte value to the StreamWriter.
writeByte(byte) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the byte value to the StreamWriter.
writeByteArray(byte[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of byte values to the StreamWriter.
writeByteArray(byte[], int, int) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the part of array of byte values to the StreamWriter, using specific offset and length values.
writeByteArray(byte[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of byte values to the StreamWriter.
writeByteArray(byte[], int, int) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the part of array of byte values to the StreamWriter, using specific offset and length values.
writeChar(char) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the char value to the StreamWriter.
writeChar(char) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the char value to the StreamWriter.
writeCharArray(char[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of char values to the StreamWriter.
writeCharArray(char[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of char values to the StreamWriter.
writeCoderProperties(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
writeDouble(double) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the double value to the StreamWriter.
writeDouble(double) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the double value to the StreamWriter.
writeDoubleArray(double[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of double values to the StreamWriter.
writeDoubleArray(double[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of double values to the StreamWriter.
writeFloat(float) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the float value to the StreamWriter.
writeFloat(float) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the float value to the StreamWriter.
writeFloatArray(float[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of float values to the StreamWriter.
writeFloatArray(float[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of float values to the StreamWriter.
WriteHandler - Interface in org.glassfish.grizzly
Callback notification mechanism that signals the developer it's possible to write content.
writeHandlersQueue - Variable in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
writeInt(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
writeInt(int) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the int value to the StreamWriter.
writeIntArray(int[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of int values to the StreamWriter.
writeIntArray(int[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of int values to the StreamWriter.
writeLong(long) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the long value to the StreamWriter.
writeLong(long) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the long value to the StreamWriter.
writeLongArray(long[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of long values to the StreamWriter.
writeLongArray(long[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of long values to the StreamWriter.
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorWriter
 
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorWriter
 
writeQueueRecord(AsyncWriteQueueRecord, MessageCloner<WritableMessage>, PushBackContext) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
Writer<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to write data from a Buffer to Connection.
WriteResult<K,L> - Class in org.glassfish.grizzly
Result of write operation, returned by Writable.
writeShort(short) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the short value to the StreamWriter.
writeShort(short) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the short value to the StreamWriter.
writeShortArray(short[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of short values to the StreamWriter.
writeShortArray(short[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of short values to the StreamWriter.
writeTimeoutMillis - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
writeTo(WritableByteChannel) - Method in class org.glassfish.grizzly.FileTransfer
Transfers the File backing this FileTransfer to the specified WritableByteChannel.

Z

ZERO - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
ZERO - Static variable in class org.glassfish.grizzly.streams.BufferedOutput
 
ZERO_READY_FUTURE - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
ZERO_READY_FUTURE - Static variable in class org.glassfish.grizzly.streams.BufferedOutput
 
zeroByteReadCount - Variable in class org.glassfish.grizzly.nio.NIOConnection
 

_

_blockSize - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_bufferBase - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_bufferOffset - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_pos - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_streamPos - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 

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

Copyright © 2012 Oracle Corporation. All Rights Reserved.