Index

A B C D E F G H I J K L M N O P Q R S T U V W Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbstractBindingHandler - Class in org.glassfish.grizzly
 
AbstractBindingHandler(NIOTransport) - Constructor for class org.glassfish.grizzly.AbstractBindingHandler
 
AbstractBindingHandler.Builder<E extends AbstractBindingHandler.Builder> - Class in org.glassfish.grizzly
Builder
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
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
 
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
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
 
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
 
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
 
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
ACCEPT - Enum constant in enum class org.glassfish.grizzly.filterchain.FilterChainContext.Operation
 
acceptAsync() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Asynchronously accept a Connection
ACCEPTED - Enum constant in enum class org.glassfish.grizzly.IOEvent
Event occurs on a client Connection, just after it was accepted by the server.
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(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
adapt(Integer) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.HandshakeCompletionHandler
 
adapt(K) - Method in interface org.glassfish.grizzly.utils.GenericAdapter
 
Adapter() - Constructor for class org.glassfish.grizzly.ConnectionProbe.Adapter
 
Adapter() - Constructor for class org.glassfish.grizzly.IOEventLifeCycleListener.Adapter
 
Adapter() - Constructor for class org.glassfish.grizzly.memory.MemoryProbe.Adapter
 
Adapter() - Constructor for class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
 
Adapter() - Constructor for class org.glassfish.grizzly.TransportProbe.Adapter
 
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(int, ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
add(E) - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
add(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(E, int, int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
add(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
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
addAll(int, Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(int, Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(int, List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(int, Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(Collection<? extends T>) - Method in class org.glassfish.grizzly.utils.ArraySet
addAll(List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(FilterChainBuilder) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(T...) - Method in class org.glassfish.grizzly.utils.ArraySet
Add the element(s) to the set.
addCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Closeable
Add the CloseListener, which will be notified once the stream will be closed.
addCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Connection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCloseListener(CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
addCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
addCompletionHandler(CompletionHandler<R>) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
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
 
addHandshakeListener(SSLBaseFilter.HandshakeListener) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
addLast(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addLifeCycleListener(IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.Context
 
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 class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Add the monitoring probes, which will be notified about object's lifecycle events.
addProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
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
 
addShutdownListener(GracefulShutdownListener) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
addShutdownListener(GracefulShutdownListener) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
addShutdownListener(GracefulShutdownListener) - Method in interface org.glassfish.grizzly.Transport
Adds a GracefulShutdownListener which will be called when Transport.shutdown() is called to enable graceful shutdown of transports.
addShutdownTask(Callable<Filter>) - Method in class org.glassfish.grizzly.filterchain.ShutdownEvent
Adds a task to this event.
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 class org.glassfish.grizzly.memory.PooledMemoryManager
For this implementation, this method simply calls through to PooledMemoryManager.allocateAtLeast(int);
allocate(int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
Creates a buffer with a given capacity and limit
allocate(int) - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
allocateAndReadBuffer(TCPNIOConnection) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
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.
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Allocates a buffer of at least the size requested.
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
Creates a new HeapBuffer with a a specified size.
allocateHeapBufferAtLeast(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
allocateInputBuffer(SSLConnectionContext) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
allocateNewBuffer(MemoryManager, int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose() - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose(boolean) - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowDispose(Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
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.memory.CompositeBuffer
 
append(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
append(T) - Method in interface org.glassfish.grizzly.Appendable
 
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 interface org.glassfish.grizzly.Buffer
Returns the byte array that backs this buffer (optional operation).
array() - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
array() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
array() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
array() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
arrayOffset() - Method in interface org.glassfish.grizzly.Buffer
Returns the offset within this buffer's backing array of the first element of the buffer (optional operation).
arrayOffset() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
arrayOffset() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
arrayOffset() - 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
 
assertOpen() - Method in interface org.glassfish.grizzly.Closeable
Checks if this Closeable is open and ready to be used.
assertOpen() - Method in interface org.glassfish.grizzly.Connection
Checks if this Connection is open and ready to be used.
assertOpen() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
AsyncQueue - Interface in org.glassfish.grizzly.asyncqueue
Common interface for AsyncQueue processors.
AsyncQueue.AsyncResult - Enum Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueEnabledTransport - Interface in org.glassfish.grizzly.asyncqueue
Interface, which Transports should implement if they support AsyncQueues.
asyncQueueIO - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Transport AsyncQueueIO
AsyncQueueIO<L> - Interface in org.glassfish.grizzly.asyncqueue
Class encapsulates asynchronous queue implementation: AsyncQueueReader, AsyncQueueWriter.
AsyncQueueIO.Factory - Class in org.glassfish.grizzly.asyncqueue
 
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() - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
AsyncQueueRecord(Connection, Object, CompletionHandler) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
AsyncQueueWriter<L> - Interface in org.glassfish.grizzly.asyncqueue
The AsyncQueue, which implements asynchronous write queue.
AsyncReadQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue read element unit
AsyncWriteQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue write element unit
AsyncWriteQueueRecord(Connection, WritableMessage, CompletionHandler, Object, PushBackHandler, boolean) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
attach() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
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, Supplier<T>) - Constructor for class org.glassfish.grizzly.attributes.Attribute
 
Attribute(AttributeBuilder, String, int, 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 - Variable in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
attributeBuilder - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
AttributeBuilder - Interface in org.glassfish.grizzly.attributes
AttributeBuilder is responsible for creating and indexing Attributes.
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
 
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
AttributeStorage - Interface in org.glassfish.grizzly.attributes
AttributeStorage provides access to a AttributeHolder, where application can store Attributes.
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
 
A B C D E F G H I J K L M N O P Q R S T U V W Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form