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

A

AbstractAsyncQueueReader - Class in com.sun.grizzly.async
 
AbstractAsyncQueueReader(SelectorHandler) - Constructor for class com.sun.grizzly.async.AbstractAsyncQueueReader
 
AbstractAsyncQueueWriter - Class in com.sun.grizzly.async
 
AbstractAsyncQueueWriter(SelectorHandler) - Constructor for class com.sun.grizzly.async.AbstractAsyncQueueWriter
 
acceptWithoutRegistration(SelectionKey) - Method in interface com.sun.grizzly.SelectorHandler
Accepts connection, without registering it for reading or writing
acceptWithoutRegistration(SelectionKey) - Method in class com.sun.grizzly.TCPSelectorHandler
Accepts connection, without registering it for reading or writing
acquire() - Method in interface com.sun.grizzly.ConnectorInstanceHandler
Acquire a ConnectorHandler
acquire() - Method in class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler
Acquire a ConnectorHandler
acquireConnectorHandler(Controller.Protocol) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandlerPool
 
acquireConnectorHandler(Controller.Protocol) - Method in interface com.sun.grizzly.ConnectorHandlerPool
Return an instance of ConnectorHandler, which corresponds to the protocol
acquireConnectorHandler(Controller.Protocol) - Method in class com.sun.grizzly.Controller
Return an instance of a ConnectorHandler based on the Protocol requested.
acquireConnectorHandler(Controller.Protocol) - Method in class com.sun.grizzly.DefaultConnectorHandlerPool
 
acquireConnectorHandler() - Method in interface com.sun.grizzly.SelectorHandler
Return an instance of the ConnectorHandler
acquireConnectorHandler() - Method in class com.sun.grizzly.TCPSelectorHandler
Return an instance of the default ConnectorHandler, which is the TCPConnectorHandler
addChannel(SelectableChannel, SelectorHandler) - Method in class com.sun.grizzly.ReadController
Add a Channel to be processed byReadController's SelectorHandler
addEventHandler(DefaultProtocolChain.EventHandler) - Method in class com.sun.grizzly.DefaultProtocolChain
Add the DefaultProtocolChain.EventHandler
addFilter(ProtocolFilter) - Method in class com.sun.grizzly.DefaultProtocolChain
Add the ProtocolFilter to this ProtocolChain
addFilter(int, ProtocolFilter) - Method in class com.sun.grizzly.DefaultProtocolChain
Insert a ProtocolFilter at position pos.
addFilter(ProtocolFilter) - Method in interface com.sun.grizzly.ProtocolChain
Add a ProtocolFilter to the list.
addFilter(int, ProtocolFilter) - Method in interface com.sun.grizzly.ProtocolChain
Insert a ProtocolFilter to the list at position 'pos'.
addProtocolSupport(Controller.Protocol) - Method in class com.sun.grizzly.RoundRobinSelectorHandler
Add custom protocol support
address - Variable in class com.sun.grizzly.async.OperationResult
 
addSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.Controller
Add a SelectorHandler
addStateListener(ControllerStateListener) - Method in class com.sun.grizzly.Controller
Add controller state listener
afterCall() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
afterCall() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
afterCall() - Method in class com.sun.grizzly.SelectionKeyContextTask
 
afterExecute(Runnable, Throwable) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
allocate(ByteBufferFactory.ByteBufferType, int) - Static method in class com.sun.grizzly.util.ByteBufferFactory
Return a new ByteBuffer based on the requested ByteBufferType
allocate(boolean, boolean, int) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Allocate a ByteBuffer
allocateThreadBuffers(int) - Static method in class com.sun.grizzly.util.SSLUtils
Allocate themandatory ByteBuffers.
allocateView(int, boolean) - Static method in class com.sun.grizzly.util.ByteBufferFactory
Return a direct ByteBuffer view
allocateView(boolean) - Static method in class com.sun.grizzly.util.ByteBufferFactory
Return a direct ByteBuffer view using the default size.
aquireSelectionKeyOP(int) - Static method in class com.sun.grizzly.util.SelectionKeyOP
 
associate() - Method in class com.sun.grizzly.util.ThreadAttachment
Associates ThreadAttachment with the current thread
associateKey(SelectionKey) - Method in class com.sun.grizzly.util.CallbackHandlerSelectionKeyAttachment
 
AsyncQueue<K,E> - Class in com.sun.grizzly.async
Class implements Map-like collection, maps keys to values, where single key could have queue of correspondent values.
AsyncQueue() - Constructor for class com.sun.grizzly.async.AsyncQueue
 
AsyncQueue.AsyncQueueEntry - Class in com.sun.grizzly.async
AsyncQueue data unit
AsyncQueue.AsyncQueueEntry() - Constructor for class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
AsyncQueueDataProcessor - Interface in com.sun.grizzly.async
Interface represents processor class, which could be used either by AsyncQueueWriter for pre processing data, which will be sent on a SelectableChannel; or by AsyncQueueReader for post processing data, which were read from a SelectableChannel.
AsyncQueueFuture<E> - Class in com.sun.grizzly.async
Async queue Future implementation
AsyncQueueFuture() - Constructor for class com.sun.grizzly.async.AsyncQueueFuture
 
AsyncQueueReadable - Interface in com.sun.grizzly.async
Object, which is able to read data to the ByteBuffer asynchronously, using queue.
AsyncQueueReader - Interface in com.sun.grizzly.async
 
asyncQueueReader - Variable in class com.sun.grizzly.TCPSelectorHandler
AsyncQueueWriter
AsyncQueueReaderContextTask - Class in com.sun.grizzly.async
AsyncQueueReader task, which will be executed by Context, when Context.execute(ContextTask) is called.
AsyncQueueReaderContextTask() - Constructor for class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
AsyncQueueReadUnit - Class in com.sun.grizzly.async
AsyncQueue write data unit
AsyncQueueReadUnit() - Constructor for class com.sun.grizzly.async.AsyncQueueReadUnit
 
AsyncQueueWritable - Interface in com.sun.grizzly.async
Object, which is able to send ByteBuffer data asynchronously, using queue.
AsyncQueueWriter - Interface in com.sun.grizzly.async
Common inteface to be implemented by protocol dependant asynchronous queue writers implementations
asyncQueueWriter - Variable in class com.sun.grizzly.TCPSelectorHandler
AsyncQueueWriter
AsyncQueueWriterContextTask - Class in com.sun.grizzly.async
AsyncQueueWriter task, which will be executed by Context, when Context.execute(ContextTask) is called.
AsyncQueueWriterContextTask() - Constructor for class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
AsyncQueueWriteUnit - Class in com.sun.grizzly.async
AsyncQueue write data unit
AsyncQueueWriteUnit() - Constructor for class com.sun.grizzly.async.AsyncQueueWriteUnit
 
AsyncReadCallbackHandler - Interface in com.sun.grizzly.async
Callback handler interface, used by AsyncQueueReader to notify custom code either about completion of specific ByteBuffer reading or about IO problem, which occured when reading data to a ByteBuffer
AsyncReadCondition - Interface in com.sun.grizzly.async
Interface represents condition, which will be checked when AsyncQueueReader was able to read new portion of data from SelectableChannel, whoch is associated with a SelectionKey.
AsyncWriteCallbackHandler - Interface in com.sun.grizzly.async
Callback handler interface, used by AsyncQueueWriter to notify custom code either about completion of specific ByteBuffer writing or about IO problem, which occured when writing ByteBuffer
attach(E) - Method in interface com.sun.grizzly.IOEvent
Attach an E and return the previous value.
attach(E) - Method in class com.sun.grizzly.IOEvent.DefaultIOEvent
 
attach(ThreadAttachment) - Method in class com.sun.grizzly.util.WorkerThread
Attach the ThreadAttachment to this instance.
attach(ThreadAttachment) - Method in class com.sun.grizzly.util.WorkerThreadImpl
 
attachChannel(F) - Method in interface com.sun.grizzly.util.Interceptor
The Channel associated with this handler.
attachment() - Method in interface com.sun.grizzly.IOEvent
Return the current attachment.
attachment() - Method in class com.sun.grizzly.IOEvent.DefaultIOEvent
 
AttributeHolder - Interface in com.sun.grizzly.util
Interface declares common functionality for objects, which could have associated attributes.
attributes - Variable in class com.sun.grizzly.Controller
Attributes, associated with the Controller instance
attributes - Variable in class com.sun.grizzly.TCPSelectorHandler
Attributes, associated with the SelectorHandler instance
ATTRIBUTES_ONLY - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
available() - Method in class com.sun.grizzly.util.InputReader
Return the available bytes

B

BaseSelectionKeyHandler - Class in com.sun.grizzly
This class is an implementation of a SelectionKeyHandler which does not use the SelectionKey attachment, does not expire keys or utilize a keep-alive mechanism.
BaseSelectionKeyHandler() - Constructor for class com.sun.grizzly.BaseSelectionKeyHandler
 
BaseSelectionKeyHandler(SelectorHandler) - Constructor for class com.sun.grizzly.BaseSelectionKeyHandler
 
beforeCall() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
beforeCall() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
beforeCall() - Method in class com.sun.grizzly.SelectionKeyContextTask
 
beforeExecute(Thread, Runnable) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
boolean2Role(boolean) - Static method in class com.sun.grizzly.TCPSelectorHandler
Returns the Role, depending on isClient value
BREAK - Static variable in interface com.sun.grizzly.util.Interceptor
Do not continue the processing.
BYTE_BUFFER - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
byteBuffer - Variable in class com.sun.grizzly.async.AsyncQueueReadUnit
 
byteBuffer - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
byteBuffer - Variable in class com.sun.grizzly.util.InputReader
The wrapped ByteBufferbyteBuffer - Variable in class com.sun.grizzly.util.WorkerThread
The ByteBuffer used when Task are executed.
byteBufferCloner - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
ByteBufferCloner - Interface in com.sun.grizzly.async
Cloner, which will be called by AsyncQueueWriter, when ByteBuffer could not be written directly, and will be added to the queue.
ByteBufferFactory - Class in com.sun.grizzly.util
Factory class used to create ByteBuffer.
ByteBufferFactory.ByteBufferType - Enum in com.sun.grizzly.util
An enumeration of all type of ByteBuffer this object can create.
ByteBufferInputStream - Class in com.sun.grizzly.util
Deprecated. - Use InputReader instead
ByteBufferInputStream() - Constructor for class com.sun.grizzly.util.ByteBufferInputStream
Deprecated.  
byteBufferType - Variable in class com.sun.grizzly.util.DefaultThreadPool
The ByteBufferFactory.ByteBufferType
bytesProcessed - Variable in class com.sun.grizzly.async.OperationResult
 

C

CacheableConnectorHandler - Class in com.sun.grizzly.connectioncache.client
Extended implementation of the DefaultSelectionKeyHandler with ConnectionManagement integrated in it
CacheableConnectorHandler(CacheableConnectorHandlerPool) - Constructor for class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
CacheableConnectorHandlerPool - Class in com.sun.grizzly.connectioncache.client
ConnectorInstanceHandler which use a ConcurrentQueue to pool CacheableConnectorHandler
CacheableConnectorHandlerPool(Controller, int, int, int) - Constructor for class com.sun.grizzly.connectioncache.client.CacheableConnectorHandlerPool
 
CacheableConnectorHandlerPool(Controller, int, int, int, ConnectionFinder<ConnectorHandler>) - Constructor for class com.sun.grizzly.connectioncache.client.CacheableConnectorHandlerPool
 
CacheableSelectionKeyHandler - Class in com.sun.grizzly.connectioncache.server
Extended implementation of the DefaultSelectionKeyHandler with ConnectionManagement integrated in it
CacheableSelectionKeyHandler() - Constructor for class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
 
CacheableSelectionKeyHandler(int, int) - Constructor for class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
Construct ConnectionManagementSelectionKeyHandler
call() - Method in class com.sun.grizzly.SelectionKeyContextTask
 
callbackHandler - Variable in class com.sun.grizzly.async.AsyncQueueReadUnit
 
callbackHandler - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
CallbackHandler<E> - Interface in com.sun.grizzly
Callback handler for non blocking client operations.
callbackHandler - Variable in class com.sun.grizzly.UDPConnectorHandler
A CallbackHandler handler invoked by the UDPSelectorHandler when a non blocking operation is ready to be processed.
CallbackHandlerContextTask - Class in com.sun.grizzly
CallbackHandler task, which will be executed by Context, when Context.execute(ContextTask) is called.
CallbackHandlerContextTask() - Constructor for class com.sun.grizzly.CallbackHandlerContextTask
 
CallbackHandlerDescriptor - Interface in com.sun.grizzly
Class represents CallbackHandler descriptor.
CallbackHandlerSelectionKeyAttachment - Class in com.sun.grizzly.util
SelectionKey attachment, which wraps CallbackHandler
cancel(boolean) - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
cancel(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Cancel a SelectionKey and close its associated Channel.
cancel(SelectionKey) - Method in class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
 
cancel() - Method in interface com.sun.grizzly.Context
Cancel a Context.suspend()ed Context.
cancel() - Method in class com.sun.grizzly.NIOContext
Cancel a NIOContext.suspend()ed Context.
cancel(SelectionKey) - Method in interface com.sun.grizzly.SelectionKeyHandler
Cancel a SelectionKey and close its Channel.
cancel() - Method in class com.sun.grizzly.suspendable.Suspendable
Cancel a suspended connection.
cancel(SelectionKey) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Cancel the connection by internalling cancelling the associated ReadableChannel and it associated SelectionKey
cancelKey(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
cancelKey(SelectionKey) - Method in class com.sun.grizzly.Controller
Deprecated.  
canCreateNewConnection(ContactInfo<C>) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
canCreateNewConnection(ContactInfo<C>) - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Determine whether a new connection could be created by the ConnectionCache or not.
capacity - Static variable in class com.sun.grizzly.util.ByteBufferFactory
The default capacity of the ByteBuffer from which views will be created.
check(E) - Method in class com.sun.grizzly.util.StateHolder.ConditionListener
 
check(E) - Method in class com.sun.grizzly.util.StateHolder.EqualConditionListener
 
check(E) - Method in class com.sun.grizzly.util.StateHolder.NotEqualConditionListener
 
checkAsyncReadCompleted(SelectionKey, SocketAddress, ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncReadCondition
Method checks, whether data, which was read to the ByteBuffer, is read completely, or custom code expects more data.
checkConditionListeners(E) - Method in class com.sun.grizzly.util.StateHolder
 
clear() - Method in class com.sun.grizzly.async.AsyncQueue
 
clearKeyAttachment(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
clone(ByteBuffer) - Method in interface com.sun.grizzly.async.ByteBufferCloner
 
clone(T) - Static method in class com.sun.grizzly.util.Cloner
Method creates a clone of given object pattern Pattern parameter should implement Copyable interface
Cloner - Class in com.sun.grizzly.util
Class Cloner creates a clone of given object, which should implement interface Copyable
Cloner() - Constructor for class com.sun.grizzly.util.Cloner
 
close() - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
Close AsyncQueueReader and release its resources
close() - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Close AsyncQueueWriter and release its resources
close() - Method in interface com.sun.grizzly.async.AsyncQueueReader
Close AsyncQueueReader and release its resources
close() - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Close AsyncQueueWriter and release its resources
close(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Close the SelectionKey's channel input or output, but keep alive the SelectionKey.
close() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
close(C) - Method in class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
Close a connection, regardless of whether the connection is busy or not.
close(C) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
Close a connection, regardless of whether the connection is busy or not.
close(C) - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Close a connection, regardless of its state.
close() - Method in interface com.sun.grizzly.ConnectorHandler
Close the underlying connection.
close(SelectionKey) - Method in interface com.sun.grizzly.SelectionKeyHandler
Close the SelectionKey's channel input or output, but keep alive the SelectionKey.
close() - Method in class com.sun.grizzly.SSLConnectorHandler
Close the underlying connection.
close() - Method in class com.sun.grizzly.TCPConnectorHandler
Close the underlying connection.
close() - Method in class com.sun.grizzly.UDPConnectorHandler
Close the underlying connection.
close() - Method in class com.sun.grizzly.util.InputReader
Close this stream.
closeChannel(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
closeChannel(SelectableChannel) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Close the underlying SelectableChannel
closeChannel(SelectableChannel) - Method in interface com.sun.grizzly.SelectorHandler
Closes SelectableChannel
closeChannel(SelectableChannel) - Method in class com.sun.grizzly.TCPSelectorHandler
Closes SelectableChannel
closeChannel(SelectableChannel) - Method in class com.sun.grizzly.UDPSelectorHandler
 
com.sun.grizzly - package com.sun.grizzly
 
com.sun.grizzly.async - package com.sun.grizzly.async
 
com.sun.grizzly.connectioncache.client - package com.sun.grizzly.connectioncache.client
 
com.sun.grizzly.connectioncache.impl.concurrent - package com.sun.grizzly.connectioncache.impl.concurrent
 
com.sun.grizzly.connectioncache.impl.transport - package com.sun.grizzly.connectioncache.impl.transport
 
com.sun.grizzly.connectioncache.server - package com.sun.grizzly.connectioncache.server
 
com.sun.grizzly.connectioncache.spi.concurrent - package com.sun.grizzly.connectioncache.spi.concurrent
 
com.sun.grizzly.connectioncache.spi.transport - package com.sun.grizzly.connectioncache.spi.transport
 
com.sun.grizzly.filter - package com.sun.grizzly.filter
 
com.sun.grizzly.suspendable - package com.sun.grizzly.suspendable
 
com.sun.grizzly.util - package com.sun.grizzly.util
 
ComplexSelectorHandler - Interface in com.sun.grizzly
A ComplexSelectorHandler handles all java.nio.channels.Selector operations similar way SelectorHandler does.
ConcurrentLinkedQueuePool<E> - Class in com.sun.grizzly.util
ObjectPool implementation based on ConcurrentLinkedQueue
ConcurrentLinkedQueuePool() - Constructor for class com.sun.grizzly.util.ConcurrentLinkedQueuePool
 
ConcurrentQueue<V> - Interface in com.sun.grizzly.connectioncache.spi.concurrent
A class that provides a very simply unbounded queue.
ConcurrentQueue.Handle<V> - Interface in com.sun.grizzly.connectioncache.spi.concurrent
A Handle provides the capability to delete an element of a ConcurrentQueue very quickly.
ConcurrentQueueBlockingImpl<V> - Class in com.sun.grizzly.connectioncache.impl.concurrent
 
ConcurrentQueueBlockingImpl() - Constructor for class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueBlockingImpl
 
ConcurrentQueueFactory - Class in com.sun.grizzly.connectioncache.spi.concurrent
A factory class for creating instances of ConcurrentQueue.
ConcurrentQueueImpl<V> - Class in com.sun.grizzly.connectioncache.impl.concurrent
 
ConcurrentQueueImpl() - Constructor for class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueImpl
 
ConcurrentQueueNonBlockingImpl<V> - Class in com.sun.grizzly.connectioncache.impl.concurrent
 
ConcurrentQueueNonBlockingImpl() - Constructor for class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueNonBlockingImpl
 
condition - Variable in class com.sun.grizzly.async.AsyncQueueReadUnit
 
configure(SSLConfig) - Method in class com.sun.grizzly.filter.SSLReadFilter
Configures SSL settings.
configure(SSLConfig) - Method in class com.sun.grizzly.SSLConnectorHandler
Configure SSLConnectorHandler's SSL settings.
configureChannel(SelectableChannel) - Method in interface com.sun.grizzly.SelectorHandler
Configure the channel operations.
configureChannel(SelectableChannel) - Method in class com.sun.grizzly.TCPConnectorHandler
configureChannel(SelectableChannel) - Method in class com.sun.grizzly.TCPSelectorHandler
Configure the channel operations.
configureContext(Context, SelectorHandler) - Method in class com.sun.grizzly.Controller
Configure the Context
configureOpType(SelectionKey) - Method in class com.sun.grizzly.NIOContext
Configure the NIOContext.currentOpType based on the SelectionKey.readyOps() values.
connect(SocketAddress, CallbackHandler, SelectorHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress, SocketAddress, CallbackHandler, SelectorHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress, SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress, SocketAddress) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
connect(SocketAddress, P, E) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress, P) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, P, E) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, P) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress) - Method in interface com.sun.grizzly.ConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SSLCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, SSLCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SSLCallbackHandler, SSLSelectorHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, SSLCallbackHandler, SSLSelectorHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress) - Method in class com.sun.grizzly.SSLConnectorHandler
Connect to hostname:port.
connect(SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, CallbackHandler, TCPSelectorHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, CallbackHandler, TCPSelectorHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress) - Method in class com.sun.grizzly.TCPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.TCPSelectorHandler
Register a CallBackHandler to this Selector.
connect(SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, CallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, CallbackHandler, UDPSelectorHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress, CallbackHandler, UDPSelectorHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
connect(SocketAddress) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
connect(SocketAddress, SocketAddress) - Method in class com.sun.grizzly.UDPConnectorHandler
Connect to hostname:port.
ConnectionCache<C extends Closeable> - Interface in com.sun.grizzly.connectioncache.spi.transport
A connection cache manages a group of connections which may be re-used for sending and receiving messages.
ConnectionCacheBase<C extends Closeable> - Class in com.sun.grizzly.connectioncache.impl.transport
 
ConnectionCacheFactory - Class in com.sun.grizzly.connectioncache.spi.transport
A factory class for creating connections caches.
ConnectionCloseHandler - Interface in com.sun.grizzly.util
Simple listener to be used when an application needs to be notified when a a SelectorHandler, ConnectionHandler or SelectionKeyHandler close a connection (ConnectionCloseHandler.locallyClosed(java.nio.channels.SelectionKey)), or when a remote client close the connection (ConnectionCloseHandler.remotlyClosed(java.nio.channels.SelectionKey)).
ConnectionFinder<C extends Closeable> - Interface in com.sun.grizzly.connectioncache.spi.transport
An instance of a ConnectionFinder may be supplied to the OutboundConnectionCache.get method.
connectionTimeout - Variable in class com.sun.grizzly.TCPConnectorHandler
Connection timeout is milliseconds
ConnectorHandler<E extends SelectorHandler,P extends CallbackHandler> - Interface in com.sun.grizzly
Client side interface used to implement non blocking client operation.
ConnectorHandlerPool<E extends ConnectorHandler> - Interface in com.sun.grizzly
Interface representing ConnectorHandler pool Implementation of this interface will be responsible for allocating/releasing client side ConnectorHandlers
connectorHandlerPool - Variable in class com.sun.grizzly.Controller
The ConnectorHandlerPool, which is responsible for creating/caching ConnectorHandler instances.
ConnectorInstanceHandler<E extends ConnectorHandler> - Interface in com.sun.grizzly
This interface is responsible of handling ConnectorHandler instance creation.
connectorInstanceHandler - Variable in class com.sun.grizzly.TCPSelectorHandler
The ConnectorInstanceHandler used to return a new or pooled ConnectorHandler
ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler<E extends ConnectorHandler> - Class in com.sun.grizzly
Concurrent Queue ConnectorInstanceHandler implementation
ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler() - Constructor for class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler
 
ConnectorInstanceHandler.ConcurrentQueueDelegateCIH<E extends ConnectorHandler> - Class in com.sun.grizzly
Concurrent Queue ConnectorInstanceHandler implementation
ConnectorInstanceHandler.ConcurrentQueueDelegateCIH(Callable<E>) - Constructor for class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueDelegateCIH
 
ContactInfo<C extends Closeable> - Interface in com.sun.grizzly.connectioncache.spi.transport
The ContactInfo represents the information needed to establish a connection to a (possibly different) process.
contentLength() - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Return the stream content-length.
Context - Interface in com.sun.grizzly
This interface is used to share information between the Grizzly Framework classes and ProtocolFilter implementation.
context - Variable in class com.sun.grizzly.ContextTask
 
Context.AttributeScope - Enum in com.sun.grizzly
 
Context.KeyRegistrationState - Enum in com.sun.grizzly
A SelectionKey's registration state.
Context.OpType - Enum in com.sun.grizzly
The list of possible SelectionKey.OP_XXXX.
ContextTask - Class in com.sun.grizzly
Task, which will be executed by Context, when Context.execute(ContextTask) is called.
ContextTask() - Constructor for class com.sun.grizzly.ContextTask
 
ContextTask.TaskPool<E extends ContextTask> - Class in com.sun.grizzly
 
ContextTask.TaskPool() - Constructor for class com.sun.grizzly.ContextTask.TaskPool
 
continousExecution - Variable in class com.sun.grizzly.DefaultProtocolChain
true if a pipelined execution is required.
continousExecution - Variable in class com.sun.grizzly.filter.ReadFilter
true if a pipelined execution is required.
CONTINUE - Static variable in interface com.sun.grizzly.util.Interceptor
Continue the processing
Controller - Class in com.sun.grizzly
Main entry point when using the Grizzly Framework.
Controller() - Constructor for class com.sun.grizzly.Controller
Controller constructor
controller - Variable in class com.sun.grizzly.UDPConnectorHandler
The internal Controller used (in case not specified).
Controller.Protocol - Enum in com.sun.grizzly
 
ControllerStateListener - Interface in com.sun.grizzly
Controller state listener interface.
ControllerStateListenerAdapter - Class in com.sun.grizzly
Empty implementation of ControllerStateListener
ControllerStateListenerAdapter() - Constructor for class com.sun.grizzly.ControllerStateListenerAdapter
 
Copyable - Interface in com.sun.grizzly.util
Copyable objects are able to copy their content to other objects of the same type
copyTo(Copyable) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Copies current object content to copy object
copyTo(Copyable) - Method in class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
 
copyTo(Copyable) - Method in class com.sun.grizzly.Controller
Copy this Controller state to another instance of a Controller.
copyTo(Copyable) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Copies current object content to copy object
copyTo(Copyable) - Method in class com.sun.grizzly.NIOContext
 
copyTo(Copyable) - Method in class com.sun.grizzly.RoundRobinSelectorHandler
 
copyTo(Copyable) - Method in class com.sun.grizzly.TCPSelectorHandler
 
copyTo(Copyable) - Method in class com.sun.grizzly.UDPSelectorHandler
 
copyTo(Copyable) - Method in interface com.sun.grizzly.util.Copyable
Copies current object content to copy object
create(CallbackHandler) - Static method in class com.sun.grizzly.util.CallbackHandlerSelectionKeyAttachment
Creates the CallbackHandler to the SelectionKey CallbackHandler will not be attached directly, but wrapped with CallbackHandlerSelectionKeyAttachment
createByteBuffer(boolean) - Method in class com.sun.grizzly.util.WorkerThreadImpl
Allocate a ByteBuffer if the current instance is null;
createConnection() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
createConnection() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ContactInfo
Create a new Connection from this ContactInfo.
createSelector() - Static method in class com.sun.grizzly.util.SelectorFactory
Creeate Selector
createSSLContext() - Method in class com.sun.grizzly.SSLConfig
 
currentElement - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 

D

datagramChannel - Variable in class com.sun.grizzly.UDPConnectorHandler
The connection's DatagramChannel.
datagramChannel - Variable in class com.sun.grizzly.UDPSelectorHandler
The DatagramChannel.
datagramSocket - Variable in class com.sun.grizzly.UDPSelectorHandler
The datagramSocket instance.
deassociate() - Method in class com.sun.grizzly.util.ThreadAttachment
Releases ThreadAttachment association with the current thread
debug() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
decrementRefCount() - Method in interface com.sun.grizzly.Context
Decrements the reference count of this Context.
decrementRefCount() - Method in class com.sun.grizzly.NIOContext
Decrements the reference count of this Context.
DEFAULT_CONFIG - Static variable in class com.sun.grizzly.SSLConfig
Default SSL configuration
DEFAULT_IDLE_THREAD_KEEPALIVE_TIMEOUT - Static variable in class com.sun.grizzly.util.DefaultThreadPool
 
DEFAULT_MAX_SELECTORS - Static variable in class com.sun.grizzly.util.SelectorFactory
 
DEFAULT_MAX_TASKS_QUEUED - Static variable in class com.sun.grizzly.util.DefaultThreadPool
 
DEFAULT_MAX_THREAD_COUNT - Static variable in class com.sun.grizzly.util.DefaultThreadPool
 
DEFAULT_MIN_THREAD_COUNT - Static variable in class com.sun.grizzly.util.DefaultThreadPool
 
DefaultCallbackHandler - Class in com.sun.grizzly
Default CallbackHandler implementation that implements the connect operations, and delegate the read and write operations to its associated SelectorHandler ProtocolChain, like the default SelectorHandler is doing server side component.
DefaultCallbackHandler(ConnectorHandler) - Constructor for class com.sun.grizzly.DefaultCallbackHandler
Create a CallbackHandler that delegate the read and write operation to the ProtocolChain associated with the ConnectorHandler
DefaultCallbackHandler(ConnectorHandler, boolean) - Constructor for class com.sun.grizzly.DefaultCallbackHandler
Create a CallbackHandler that delegate the read and write operation to the ProtocolChain associated with the ConnectorHandler.
defaultCapacity - Static variable in class com.sun.grizzly.util.ByteBufferFactory
The default capacity of the default view of a ByteBuffer
DefaultConnectorHandlerPool - Class in com.sun.grizzly
Simple ConnectorHandlerPool implementation
DefaultConnectorHandlerPool(Controller) - Constructor for class com.sun.grizzly.DefaultConnectorHandlerPool
 
DefaultProtocolChain - Class in com.sun.grizzly
Default ProtocolChain implementation.
DefaultProtocolChain() - Constructor for class com.sun.grizzly.DefaultProtocolChain
 
DefaultProtocolChain.EventHandler - Interface in com.sun.grizzly
Interface, which introduces handler, which will be notified about event, happened on ProtocolChain
DefaultProtocolChain.Phase - Enum in com.sun.grizzly
 
DefaultProtocolChainInstanceHandler - Class in com.sun.grizzly
Default implementation of an ProtocolChainInstanceHandler.
DefaultProtocolChainInstanceHandler() - Constructor for class com.sun.grizzly.DefaultProtocolChainInstanceHandler
 
DefaultSelectionKeyHandler - Class in com.sun.grizzly
Default implementation of a SelectionKey Handler.
DefaultSelectionKeyHandler() - Constructor for class com.sun.grizzly.DefaultSelectionKeyHandler
 
DefaultSelectionKeyHandler(SelectorHandler) - Constructor for class com.sun.grizzly.DefaultSelectionKeyHandler
 
DefaultThreadPool - Class in com.sun.grizzly.util
Thread Pool implementation, based on ThreadPoolExecutor
DefaultThreadPool() - Constructor for class com.sun.grizzly.util.DefaultThreadPool
 
DefaultThreadPool(int, int, int, long, TimeUnit) - Constructor for class com.sun.grizzly.util.DefaultThreadPool
 
detach() - Method in class com.sun.grizzly.util.WorkerThread
Detach the current set of attributes (state) associated with this instance.
detach() - Method in class com.sun.grizzly.util.WorkerThreadImpl
 
doCall() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
doCall() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
doCall() - Method in class com.sun.grizzly.CallbackHandlerContextTask
 
doCall() - Method in class com.sun.grizzly.ProtocolChainContextTask
 
doCall() - Method in class com.sun.grizzly.SelectionKeyContextTask
 
doClearRead() - Method in class com.sun.grizzly.util.InputReader
 
doHandshake(SelectableChannel, ByteBuffer, ByteBuffer, ByteBuffer, SSLEngine, SSLEngineResult.HandshakeStatus) - Static method in class com.sun.grizzly.util.SSLUtils
Perform an SSL handshake using the SSLEngine.
doHandshake(SelectableChannel, ByteBuffer, ByteBuffer, ByteBuffer, SSLEngine, SSLEngineResult.HandshakeStatus, int) - Static method in class com.sun.grizzly.util.SSLUtils
Perform an SSL handshake using the SSLEngine.
doHandshake(SelectableChannel, ByteBuffer, ByteBuffer, ByteBuffer, SSLEngine, SSLEngineResult.HandshakeStatus, int, boolean) - Static method in class com.sun.grizzly.util.SSLUtils
Perform an SSL handshake using the SSLEngine.
doPeerCertificateChain(SelectionKey, boolean) - Static method in class com.sun.grizzly.filter.SSLReadFilter
Get the peer certificate list by initiating a new handshake.
doPeerCertificateChain(SelectableChannel, ByteBuffer, ByteBuffer, ByteBuffer, SSLEngine, boolean, int) - Static method in class com.sun.grizzly.util.SSLUtils
Get the peer certificate list by initiating a new handshake.
doRead(ReadableByteChannel, ByteBuffer, AsyncQueueDataProcessor, OperationResult) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
 
doRead(ReadableByteChannel, ByteBuffer, AsyncQueueDataProcessor, OperationResult) - Method in class com.sun.grizzly.async.TCPAsyncQueueReader
 
doRead(ReadableByteChannel, ByteBuffer, AsyncQueueDataProcessor, OperationResult) - Method in class com.sun.grizzly.async.UDPAsyncQueueReader
 
doRead() - Method in class com.sun.grizzly.util.InputReader
Read bytes using the read ReadSelector
doRead(SelectableChannel, ByteBuffer, SSLEngine, int) - Static method in class com.sun.grizzly.util.SSLUtils
Read encrypted bytes using anSSLEngine.
doRegisterKey(SelectionKey, int) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Registers SelectionKey to handle certain operations
doRegisterKey(SelectionKey, int, long) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Registers SelectionKey to handle certain operations
doSecureRead() - Method in class com.sun.grizzly.util.InputReader
Read and decrypt bytes from the underlying SSL connections.
doSecureRead(SelectableChannel, SSLEngine, ByteBuffer, ByteBuffer) - Static method in class com.sun.grizzly.util.SSLUtils
Read and decrypt bytes from the underlying SSL connections.
doSelect(SelectorHandler) - Method in class com.sun.grizzly.Controller
This method handle the processing of all Selector's interest op (OP_ACCEPT,OP_READ,OP_WRITE,OP_CONNECT) by delegating to its Handler.
doWrite(WritableByteChannel, SocketAddress, ByteBuffer, AsyncQueueDataProcessor, OperationResult) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
 
doWrite(WritableByteChannel, SocketAddress, ByteBuffer, OperationResult) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
 
doWrite(WritableByteChannel, SocketAddress, ByteBuffer, OperationResult) - Method in class com.sun.grizzly.async.TCPAsyncQueueWriter
 
doWrite(WritableByteChannel, SocketAddress, ByteBuffer, OperationResult) - Method in class com.sun.grizzly.async.UDPAsyncQueueWriter
 
dprint(String) - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
dprintStatistics() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
dstAddress - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 

E

EchoAsyncWriteQueueFilter - Class in com.sun.grizzly.filter
Simple echo filter
EchoAsyncWriteQueueFilter() - Constructor for class com.sun.grizzly.filter.EchoAsyncWriteQueueFilter
 
EchoFilter - Class in com.sun.grizzly.filter
Simple echo filter
EchoFilter() - Constructor for class com.sun.grizzly.filter.EchoFilter
 
equals(Object) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
equalVersion(int, int) - Static method in class com.sun.grizzly.Grizzly
Checks if current Grizzly framework version equals to one passed
eventHandlers - Variable in class com.sun.grizzly.DefaultProtocolChain
The list of DefaultProtocolChain.EventHandlers, which will be notified about this ProtocolChain events
execute() - Method in interface com.sun.grizzly.Context
Deprecated.  
execute(ContextTask) - Method in interface com.sun.grizzly.Context
Execute this Context using the Controller's thread pool
execute(ContextTask, boolean) - Method in interface com.sun.grizzly.Context
Execute this Context using either Controller's thread pool or current thread
execute(Context) - Method in class com.sun.grizzly.DefaultProtocolChain
Execute this ProtocolChain.
execute(Context, int) - Method in class com.sun.grizzly.DefaultProtocolChain
Execute this ProtocolChain.
execute(Context) - Method in class com.sun.grizzly.filter.EchoAsyncWriteQueueFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.EchoFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.LogFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Read available bytes and delegate the processing of them to the next ProtocolFilter in the ProtocolChain.
execute(Context) - Method in class com.sun.grizzly.filter.ReadFilter
Read available bytes and delegate the processing of them to the next ProtocolFilter in the ProtocolChain.
execute(Context, ByteBuffer) - Method in class com.sun.grizzly.filter.ReadFilter
Read available bytes to the specific ByteBuffer and delegate the processing of them to the next ProtocolFilter in the ProtocolChain.
execute(Context) - Method in class com.sun.grizzly.filter.SSLEchoAsyncWriteQueueFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.SSLEchoFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.SSLReadFilter
 
execute(Context) - Method in class com.sun.grizzly.filter.UDPReadFilter
Deprecated. Read available bytes and delegate the processing of them to the next ProtocolFilter in the ProtocolChain.
execute(Context) - Method in class com.sun.grizzly.filter.UDPWriteFilter
Write available bytes and delegate the processing of them to the next ProtocolFilter in the ProtocolChain.
execute() - Method in class com.sun.grizzly.NIOContext
Deprecated.  
execute(ContextTask) - Method in class com.sun.grizzly.NIOContext
Execute this Context using the Controller's thread pool
execute(ContextTask, boolean) - Method in class com.sun.grizzly.NIOContext
Execute this Context using either Controller's thread pool or current thread
execute(Context) - Method in interface com.sun.grizzly.ProtocolChain
Execute using the Context instance.
execute(Context) - Method in interface com.sun.grizzly.ProtocolFilter
Execute a unit of processing work to be performed.
execute(Context) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Excute the pattern matching algorithm to determine if a the current connection must be suspended or not, and when.
executeDelegatedTask(SSLEngine) - Static method in class com.sun.grizzly.util.SSLUtils
Complete hanshakes operations.
executeProtocolFilter(Context) - Method in class com.sun.grizzly.DefaultProtocolChain
Execute the ProtocolFilter.execute method.
executeProtocolFilter(Context, int) - Method in class com.sun.grizzly.DefaultProtocolChain
Execute the ProtocolFilter.execute method.
expire(SelectionKey, long) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Deprecated.  
expire(Iterator<SelectionKey>) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Expire a SelectionKey set.
expire(SelectionKey, long) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Deprecated.  
expire(Iterator<SelectionKey>) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Expire a SelectionKey set.
expire(SelectionKey, long) - Method in interface com.sun.grizzly.SelectionKeyHandler
Deprecated.  
expire(Iterator<SelectionKey>) - Method in interface com.sun.grizzly.SelectionKeyHandler
Expire a SelectionKey set.
expired(A) - Method in interface com.sun.grizzly.suspendable.SuspendableHandler
Invoked when a suspendable is expired (using the timeout value specified by calling SuspendableFilter.suspend(java.lang.String))
ExtendedThreadPool - Interface in com.sun.grizzly.util
Thread pool, from which it's possible to gather statistics information, and finer control its execution.
extractBytes(ByteBuffer, byte, byte) - Static method in class com.sun.grizzly.util.Utils
Return the bytes contained between the startByte and the endByte.

F

find(ContactInfo<C>, Collection<C>, Collection<C>) - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionFinder
Method that searches idleConnections and busyConnections for the best connection.
findBytes(ByteBuffer, byte[]) - Static method in class com.sun.grizzly.util.Utils
Specialized utility method: find a sequence of lower case bytes inside a ByteBuffer.
finishConnect(SelectionKey) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
finishConnect(SelectionKey) - Method in interface com.sun.grizzly.ConnectorHandler
Decide how the OP_CONNECT final steps are handled.
finishConnect(SelectionKey) - Method in class com.sun.grizzly.SSLConnectorHandler
Finish handling the OP_CONNECT interest ops.
finishConnect(SelectionKey) - Method in class com.sun.grizzly.TCPConnectorHandler
Finish handling the OP_CONNECT interest ops.
finishConnect(SelectionKey) - Method in class com.sun.grizzly.UDPConnectorHandler
Finish handling the OP_CONNECT interest ops.
finishHandshake() - Method in class com.sun.grizzly.SSLConnectorHandler
Changes SSLConnectorHandler state, after handshake operation is done.
flushChannel(SelectableChannel, ByteBuffer) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(SelectableChannel, ByteBuffer, long) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(SocketChannel, ByteBuffer[]) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(SocketChannel, ByteBuffer[], long) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(DatagramChannel, SocketAddress, ByteBuffer) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(DatagramChannel, SocketAddress, ByteBuffer, long) - Static method in class com.sun.grizzly.util.OutputWriter
Flush the buffer by looping until the ByteBuffer is empty
flushChannel(SelectableChannel, ByteBuffer) - Static method in class com.sun.grizzly.util.SSLOutputWriter
Encrypt the response and flush it using OutputWriter
flushChannel(SelectableChannel, ByteBuffer, ByteBuffer, SSLEngine) - Static method in class com.sun.grizzly.util.SSLOutputWriter
Encrypt the response and flush it using OutputWriter
format(LogRecord) - Method in class com.sun.grizzly.util.LoggingFormatter
Format the record to include the Thread that logged this record.
future - Variable in class com.sun.grizzly.async.AsyncQueueReadUnit
 
future - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 

G

get() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
get(long, TimeUnit) - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
get(ContactInfo<C>) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
get(ContactInfo<C>, ConnectionFinder<C>) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
get(ContactInfo<C>, ConnectionFinder<C>) - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Return a Connection corresponding to the given ContactInfo.
get(ContactInfo<C>) - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Behaves the same as get( ContactInfo, ConnectionFinder ) except that no connection finder is provided, so that step is ignored.
getActiveCount() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the approximate number of threads that are actively executing tasks.
getApplicationBufferSize() - Method in class com.sun.grizzly.SSLConnectorHandler
Gets the size of the largest application buffer that may occur when using this session.
getAsyncQueue(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
Gets ready asynchronous queue elements to be read from the SelectableChannel, associated with the given SelectionKey
getAsyncQueue(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Gets ready asynchronous queue elements to be written to the SelectableChannel, associated with the given SelectionKey
getAsyncQueue(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueReader
Gets ready asynchronous queue elements to be read from the SelectableChannel, associated with the given SelectionKey
getAsyncQueue(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Gets ready asynchronous queue elements to be written to the SelectableChannel, associated with the given SelectionKey
getAsyncQueueEntry(K) - Method in class com.sun.grizzly.async.AsyncQueue
 
getAsyncQueueReadable() - Method in class com.sun.grizzly.NIOContext
Returns AsyncQueueReadable, assciated with the current Context.
getAsyncQueueReader() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
getAsyncQueueReader() - Method in interface com.sun.grizzly.Context
Return the
getAsyncQueueReader() - Method in class com.sun.grizzly.NIOContext
Return the
getAsyncQueueReader() - Method in interface com.sun.grizzly.SelectorHandler
Returns AsyncQueueReader associated with this SelectorHandler.
getAsyncQueueReader() - Method in class com.sun.grizzly.TCPSelectorHandler
Returns AsyncQueueReader associated with this SelectorHandler.
getAsyncQueueWritable() - Method in interface com.sun.grizzly.Context
Returns AsyncQueueWritable, assciated with the current Context.
getAsyncQueueWritable() - Method in class com.sun.grizzly.NIOContext
Returns AsyncQueueWritable, assciated with the current Context.
getAsyncQueueWriter() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
getAsyncQueueWriter() - Method in class com.sun.grizzly.NIOContext
Return the
getAsyncQueueWriter() - Method in interface com.sun.grizzly.SelectorHandler
Returns AsyncQueueWriter associated with this SelectorHandler.
getAsyncQueueWriter() - Method in class com.sun.grizzly.TCPSelectorHandler
Returns AsyncQueueWriter associated with this SelectorHandler.
getAttachment() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getAttachment(SelectionKey) - Static method in class com.sun.grizzly.util.SelectionKeyAttachment
 
getAttachment() - Method in class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
getAttachment() - Method in class com.sun.grizzly.util.WorkerThread
Get the current set of attributes (state) associated with this instance.
getAttachment() - Method in class com.sun.grizzly.util.WorkerThreadImpl
 
getAttribute(String) - Method in class com.sun.grizzly.Controller
Return an object based on a key.
getAttribute(String) - Method in class com.sun.grizzly.NIOContext
Return an object based on a key.
getAttribute(String) - Method in class com.sun.grizzly.TCPSelectorHandler
Return an object based on a key.
getAttribute(String) - Method in interface com.sun.grizzly.util.AttributeHolder
Return an object based on a name.
getAttribute(String) - Method in class com.sun.grizzly.util.ThreadAttachment
 
getAttributeHolderByScope(Context.AttributeScope) - Method in interface com.sun.grizzly.Context
Return AttributeHolder, which corresponds to the given Context.AttributeScope>
getAttributeHolderByScope(Context.AttributeScope) - Method in class com.sun.grizzly.NIOContext
Return AttributeHolder, which corresponds to the given AttributeScope>
getAttributes() - Method in interface com.sun.grizzly.Context
Return a Map of attribute name/value pairs.
getAttributes() - Method in class com.sun.grizzly.Controller
Return a Map of attribute name/value pairs.
getAttributes() - Method in class com.sun.grizzly.NIOContext
Return a Map of attribute name/value pairs.
getAttributes() - Method in class com.sun.grizzly.TCPSelectorHandler
Return a Map of attribute name/value pairs.
getAttributes() - Method in interface com.sun.grizzly.util.AttributeHolder
Return a Map of attribute name/value pairs.
getAttributes() - Method in class com.sun.grizzly.util.ThreadAttachment
 
getByteBuffer() - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
getByteBuffer() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
getByteBuffer() - Method in class com.sun.grizzly.util.InputReader
Get the wrapped ByteBuffer
getByteBuffer() - Method in class com.sun.grizzly.util.ThreadAttachment
Return the ByteBuffer shared this thread
getByteBuffer() - Method in class com.sun.grizzly.util.WorkerThread
Return the ByteBuffer shared this thread
getByteBufferCloner() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
getByteBufferType() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getByteBufferType() - Method in class com.sun.grizzly.util.WorkerThreadImpl
The ByteBufferType used to create the ByteBuffer associated with this object.
getCacheType() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
getCacheType() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
User-provided indentifier for an instance of the ConnectionCache.
getCallbackHandler() - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
getCallbackHandler() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
getCallBackHandler() - Method in class com.sun.grizzly.CallbackHandlerContextTask
 
getCallbackHandler() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
getCallbackHandler() - Method in interface com.sun.grizzly.ConnectorHandler
Returns ConnectorHandler's callback handler instance, which is used to process occuring events
getCallbackHandler() - Method in class com.sun.grizzly.SSLConnectorHandler
Return the CallbackHandler.
getCallbackHandler() - Method in class com.sun.grizzly.TCPConnectorHandler
Return the CallbackHandler.
getCallbackHandler() - Method in class com.sun.grizzly.UDPConnectorHandler
Return the CallbackHandler.
getCallbackHandler() - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
getChannel() - Method in class com.sun.grizzly.util.SelectionKeyOP
 
getChannelType() - Method in class com.sun.grizzly.util.InputReader
Return the Channel type.
getCompletedTaskCount() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the approximate total number of tasks that have completed execution.
getCondition() - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
getConnectionCloseHandler() - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Return the ConnectionClosedHandler.
getConnectionState(ContactInfo<C>, OutboundConnectionCacheBlockingImpl.CacheEntry<C>, C) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
getConnectionTimeout() - Method in class com.sun.grizzly.TCPConnectorHandler
Get TCP channel connection timeout in milliseconds
getConnectorHandlerPool() - Method in class com.sun.grizzly.Controller
Return the ConnectorHandlerPool used.
getConnectorInstanceHandlerDelegate() - Method in class com.sun.grizzly.SSLSelectorHandler
 
getConnectorInstanceHandlerDelegate() - Method in class com.sun.grizzly.TCPSelectorHandler
Return factory object, which knows how to create ConnectorInstanceHandler corresponding to the protocol
getConnectorInstanceHandlerDelegate() - Method in class com.sun.grizzly.UDPSelectorHandler
 
getContext() - Method in class com.sun.grizzly.ContextTask
 
getController() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
getController() - Method in interface com.sun.grizzly.ConnectorHandler
Return the Controller
getController() - Method in interface com.sun.grizzly.Context
Return the current Controller.
getController() - Method in class com.sun.grizzly.NIOContext
Return the current Controller.
getController() - Method in class com.sun.grizzly.SSLConnectorHandler
Return the Controller
getController() - Method in class com.sun.grizzly.TCPConnectorHandler
Return the Controller
getController() - Method in class com.sun.grizzly.UDPConnectorHandler
Return the Controller
getCorePoolSize() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the core number of threads.
getCurrentOpType() - Method in interface com.sun.grizzly.Context
Get the current SelectionKey interest ops this instance is executing.
getCurrentOpType() - Method in class com.sun.grizzly.NIOContext
Get the current SelectionKey interest ops this instance is executing.
getDefaultReadTimeout() - Static method in class com.sun.grizzly.util.InputReader
Return the Selector.select() default time out.
getDefaultWriteTimeout() - Static method in class com.sun.grizzly.util.OutputWriter
 
getDelegateSSLTasks() - Method in class com.sun.grizzly.SSLConnectorHandler
 
getDotedVersion() - Static method in class com.sun.grizzly.Grizzly
Return the dotted version of the curent release.
getDstAddress() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
getEnabledCipherSuites() - Method in class com.sun.grizzly.filter.SSLReadFilter
Returns the list of cipher suites to be enabled when SSLEngine is initialized.
getEnabledProtocols() - Method in class com.sun.grizzly.filter.SSLReadFilter
Returns the list of protocols to be enabled when SSLEngine is initialized.
getException() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
getExpireTime() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getForeignKey() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
getFuture() - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
getFuture() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
getHandler() - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. The Interceptor associated with this algorithm.
getHandlerController(Handler) - Static method in class com.sun.grizzly.Controller
Return the Controller which is handling the Handler
getInet() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getInitialByteBufferSize() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getInputBB() - Method in class com.sun.grizzly.util.ThreadAttachment
Return the encrypted ByteBuffer used to handle request.
getInputBB() - Method in class com.sun.grizzly.util.WorkerThread
Return the encrypted ByteBuffer used to handle request.
getInternalByteBuffer() - Method in interface com.sun.grizzly.async.AsyncQueueDataProcessor
Method returns the processor's internal ByteBuffer.
getIOEvent() - Method in interface com.sun.grizzly.Context
Return the current IOEvent associated with this instance.
getIOEvent() - Method in class com.sun.grizzly.NIOContext
Return the current IOEvent associated with this instance.
getKeepAliveTime(TimeUnit) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the thread keep-alive time, which is the amount of time which threads in excess of the core pool size may remain idle before being terminated.
getKey() - Method in class com.sun.grizzly.suspendable.Suspendable
Return the underlying SelectionKey representing the connection.
getKey() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
getKeyRegistrationState() - Method in interface com.sun.grizzly.Context
Return SelectionKey's next registration state, or null if not supported.
getKeyRegistrationState() - Method in class com.sun.grizzly.NIOContext
Return SelectionKey's next registration state.
getKeyStoreAlgorithm() - Method in class com.sun.grizzly.SSLConfig
 
getKeyStoreFile() - Method in class com.sun.grizzly.SSLConfig
 
getKeyStorePass() - Method in class com.sun.grizzly.SSLConfig
 
getKeyStoreType() - Method in class com.sun.grizzly.SSLConfig
 
getLargestPoolSize() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the largest number of threads that have ever simultaneously been in the pool.
getLinger() - Method in class com.sun.grizzly.TCPConnectorHandler
 
getLinger() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getLinger() - Method in class com.sun.grizzly.UDPSelectorHandler
 
getLocalAddress() - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
getLogger() - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
getLogger() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getMajorVersion() - Static method in class com.sun.grizzly.Grizzly
Get Grizzly framework major version
getMaximumPoolSize() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the maximum allowed number of threads.
getMaxQueuedTasksCount() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getMaxQueuedTasksCount() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
 
getMaxSelectors() - Static method in class com.sun.grizzly.util.SelectorFactory
Returns max selector pool size
getMinorVersion() - Static method in class com.sun.grizzly.Grizzly
Get Grizzly framework minor version
getMode() - Method in class com.sun.grizzly.util.ThreadAttachment
 
getName() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getName() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
 
getNextMessage() - Method in interface com.sun.grizzly.ProtocolParser
Get the next complete message from the buffer, which can then be processed by the next filter in the protocol chain.
getOp() - Method in class com.sun.grizzly.util.SelectionKeyOP
 
getOutputBB() - Method in class com.sun.grizzly.util.ThreadAttachment
Return the encrypted ByteBuffer used to handle response.
getOutputBB() - Method in class com.sun.grizzly.util.WorkerThread
Return the encrypted ByteBuffer used to handle response.
getPoolSize() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the current number of threads in the pool.
getPort() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getPort() - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Return the port
getPortLowLevel() - Method in class com.sun.grizzly.TCPSelectorHandler
Returns port number SelectorHandler is listening on Similar to getPort(), but getting port number directly from connection (ServerSocket, DatagramSocket).
getPortLowLevel() - Method in class com.sun.grizzly.UDPSelectorHandler
 
getPreferredSelectionKeyHandler() - Method in interface com.sun.grizzly.SelectorHandler
Get the preffered SelectionKeyHandler implementation for this SelectorHandler.
getPreferredSelectionKeyHandler() - Method in class com.sun.grizzly.TCPSelectorHandler
Get the preffered SelectionKeyHandler implementation for this SelectorHandler.
getPreferredSelectionKeyHandler() - Method in class com.sun.grizzly.UDPSelectorHandler
Get the preffered SelectionKeyHandler implementation for this SelectorHandler.
getPriority() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getProtocol() - Method in interface com.sun.grizzly.Context
Return the current Controller#Protocol this instance is executing.
getProtocol() - Method in class com.sun.grizzly.NIOContext
Return the current Controller#Protocol this instance is executing.
getProtocolChain() - Method in interface com.sun.grizzly.Context
Return ProtocolChain executed by this instance.
getProtocolChain() - Method in class com.sun.grizzly.NIOContext
Return ProtocolChain executed by this instance.
getProtocolChain() - Method in class com.sun.grizzly.SingleProtocolChainInstanceHandler
Get the stateless ProtocolChain instance, which is always returned via StatelessProtocolChainInstanceHandler#poll().
getProtocolChainInstanceHandler() - Method in class com.sun.grizzly.Controller
Return the ProtocolChainInstanceHandler
getProtocolChainInstanceHandler() - Method in class com.sun.grizzly.NIOContext
Return the ProtocolChainInstanceListener associated with this Context
getProtocolChainInstanceHandler() - Method in interface com.sun.grizzly.SelectorHandler
Return the ProtocolChainInstanceHandler
getProtocolChainInstanceHandler() - Method in class com.sun.grizzly.TCPSelectorHandler
Return the ProtocolChainInstanceHandler
getQueue() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the task queue used by this executor.
getQueuedTasksCount() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getQueueSize() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
getQueueSize() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the number of tasks, which are currently waiting in the queue.
getReadAttempts() - Method in class com.sun.grizzly.filter.ReadFilter
Get the number of attempts the ReadFilter will try to read a data from a channel.
getReadPostProcessor() - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
getReadThreadsCount() - Method in class com.sun.grizzly.Controller
Return the number of Reader threads count.
getReadTimeout() - Method in class com.sun.grizzly.util.InputReader
Return the timeout between two consecutives Selector.select() when a temporary Selector is used.
getReadTimeout() - Static method in class com.sun.grizzly.util.SSLUtils
 
getRegistrationTime() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
getRemoteAddress() - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
getResult() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
getRole() - Method in class com.sun.grizzly.TCPSelectorHandler
Gets this SelectorHandler current role.
getSecuredInputBuffer() - Method in class com.sun.grizzly.SSLConnectorHandler
Returns SSLConnectorHandler's secured input buffer, it uses for reading data from a socket channel.
getSecuredOutputBuffer() - Method in class com.sun.grizzly.SSLConnectorHandler
Returns SSLConnectorHandler's secured output buffer, it uses for writing data to a socket channel.
getSecurityProtocol() - Method in class com.sun.grizzly.SSLConfig
 
getSelectionKey() - Method in interface com.sun.grizzly.Context
Return the current SelectionKey or null if {@link SelectionKey aren't supported.
getSelectionKey() - Method in class com.sun.grizzly.NIOContext
Return the current SelectionKey.
getSelectionKey() - Method in class com.sun.grizzly.util.SelectionKeyOP
 
getSelectionKeyHandler() - Method in class com.sun.grizzly.Controller
Deprecated. Return the SelectionKeyHandler Method is deprecated. Use SelectorHandler.getSelectionKeyHandler() instead
getSelectionKeyHandler() - Method in interface com.sun.grizzly.SelectorHandler
Get the SelectionKeyHandler associated with this SelectorHandler.
getSelectionKeyHandler() - Method in class com.sun.grizzly.TCPSelectorHandler
Get the SelectionKeyHandler associated with this SelectorHandler.
getSelector() - Method in interface com.sun.grizzly.SelectorHandler
Gets the underlying selector.
getSelector() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getSelector() - Static method in class com.sun.grizzly.util.SelectorFactory
Get a exclusive Selector
getSelectorHandler() - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Get associated SelectorHandler
getSelectorHandler() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
getSelectorHandler() - Method in interface com.sun.grizzly.ConnectorHandler
Method returns SelectorHandler, which manages this ConnectorHandler
getSelectorHandler() - Method in interface com.sun.grizzly.Context
Return the current SelectorHandler this instance is executing, or null if not supported.
getSelectorHandler(Controller.Protocol) - Method in class com.sun.grizzly.Controller
Return the SelectorHandler associated with the protocol.
getSelectorHandler(Selector) - Method in class com.sun.grizzly.Controller
Return the SelectorHandler associated with the Selector.
getSelectorHandler() - Method in class com.sun.grizzly.NIOContext
 
getSelectorHandler() - Method in interface com.sun.grizzly.SelectionKeyHandler
Get associated SelectorHandler
getSelectorHandler() - Method in class com.sun.grizzly.SelectorHandlerRunner
 
getSelectorHandler() - Method in class com.sun.grizzly.SSLConnectorHandler
Return the associated SelectorHandler.
getSelectorHandler() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getSelectorHandler() - Method in class com.sun.grizzly.TCPConnectorHandler
Return the associated SelectorHandler.
getSelectorHandler() - Method in class com.sun.grizzly.UDPConnectorHandler
Return the associated SelectorHandler.
getSelectorHandlerClone(SelectorHandler) - Method in class com.sun.grizzly.ReadController
Gets SelectorHandler's clone, registered on thisReadController
getSelectorHandlers() - Method in class com.sun.grizzly.Controller
Return the list SelectorHandler
getSelectTimeout() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getServerTimeout() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getSocketTimeout() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getSocketTimeout() - Method in class com.sun.grizzly.UDPSelectorHandler
 
getSsBackLog() - Method in class com.sun.grizzly.TCPSelectorHandler
 
getSsBackLog() - Method in class com.sun.grizzly.UDPSelectorHandler
 
getSSLContext() - Method in class com.sun.grizzly.filter.SSLReadFilter
Return the SSLContext required to support SSL over NIO.
getSSLContext() - Method in class com.sun.grizzly.SSLConnectorHandler
Get SSLConnector's SSLContext
getSSLEngine() - Method in class com.sun.grizzly.SSLConnectorHandler
Returns SSLConnector'sSSLEngine
getSSLEngine() - Method in class com.sun.grizzly.util.ThreadAttachment
Set theSSLEngine.
getSSLEngine() - Method in class com.sun.grizzly.util.WorkerThread
Set theSSLEngine.
getState() - Method in class com.sun.grizzly.util.StateHolder
Gets current state Current StateHolder locking mode will be used
getState(boolean) - Method in class com.sun.grizzly.util.StateHolder
Gets current state
getStateHolder() - Method in class com.sun.grizzly.Controller
Gets this Controller's StateHolder
getStateHolder() - Method in class com.sun.grizzly.TCPSelectorHandler
Gets StateHolder for this object
getStateHolder() - Method in interface com.sun.grizzly.util.SupportStateHolder
Gets StateHolder for this object
getStateLocker() - Method in class com.sun.grizzly.util.StateHolder
Gets Read/Write locker, which is used by this StateHolder
getSuspendable() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getSuspendableFilter() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getSuspendableHandler() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
getSuspendableHandler() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getSuspendWhen() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
getTaskCount() - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Returns the approximate total number of tasks that have been scheduled for execution.
getThreadAttachment() - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
getThreadId() - Method in class com.sun.grizzly.util.ThreadAttachment
Return the name of the Thread on which this instance is binded.
getThreadPool() - Method in interface com.sun.grizzly.Context
Return the ExecutorService executing this instance.
getThreadPool() - Method in class com.sun.grizzly.Controller
Return the ExecutorService (Thread Pool) used by this Controller.
getThreadPool() - Method in class com.sun.grizzly.NIOContext
Return the ExecutorService executing this instance.
getThreadPool() - Method in interface com.sun.grizzly.SelectorHandler
Return the ExecutorService used to execute this SelectorHandler's SelectionKey ops
getThreadPool() - Method in class com.sun.grizzly.TCPSelectorHandler
Return the ExecutorService used to execute this SelectorHandler's SelectionKey ops
getTimeout() - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
 
getTimeout() - Method in class com.sun.grizzly.util.CallbackHandlerSelectionKeyAttachment
Callback handler never should lead to the timeout situation, as connections could use it, but perform IO operations in sync. mode.
getTimeout() - Method in class com.sun.grizzly.util.SelectionKeyAttachment
 
getTrustStoreAlgorithm() - Method in class com.sun.grizzly.SSLConfig
 
getTrustStoreFile() - Method in class com.sun.grizzly.SSLConfig
 
getTrustStorePass() - Method in class com.sun.grizzly.SSLConfig
 
getTrustStoreType() - Method in class com.sun.grizzly.SSLConfig
 
getUnderlyingChannel() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
getUnderlyingChannel() - Method in interface com.sun.grizzly.ConnectorHandler
Method returns ConnectorHandler's underlying channel
getUnderlyingChannel() - Method in class com.sun.grizzly.SSLConnectorHandler
Return the current SocketChannel used.
getUnderlyingChannel() - Method in class com.sun.grizzly.TCPConnectorHandler
Return the current SocketChannel used.
getUnderlyingChannel() - Method in class com.sun.grizzly.UDPConnectorHandler
Return the current SocketChannel used.
getWritePreProcessor() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
Grizzly - Class in com.sun.grizzly
Class contains information about Grizzly framework
Grizzly() - Constructor for class com.sun.grizzly.Grizzly
 

H

handle(E, int) - Method in interface com.sun.grizzly.util.Interceptor
Handle and the associated handler code.
Handler - Interface in com.sun.grizzly
Marker interface.
handshake(ByteBuffer, boolean) - Method in class com.sun.grizzly.SSLConnectorHandler
Initiate SSL handshake phase.
hashCode() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
hasMoreBytesToParse() - Method in interface com.sun.grizzly.ProtocolParser
Are there more bytes to be parsed in the ByteBuffer given to this ProtocolParser's ProtocolParser#startBuffer() ?
hasNextMessage() - Method in interface com.sun.grizzly.ProtocolParser
Indicates whether the buffer has a complete message that can be returned from ProtocolParser.getNextMessage().
headerLength() - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Return the stream header length.
highWaterMark() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
highWaterMark() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Threshold at which connection reclamation begins.
hsBB - Static variable in class com.sun.grizzly.util.SSLUtils
 

I

InboundConnectionCache<C extends Closeable> - Interface in com.sun.grizzly.connectioncache.spi.transport
A concurrent connection cache for passively created connections (e.g.
InboundConnectionCacheBlockingImpl<C extends Closeable> - Class in com.sun.grizzly.connectioncache.impl.transport
Manage connections that are initiated from another VM.
InboundConnectionCacheBlockingImpl(String, int, int, Logger) - Constructor for class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
 
incrementRefCount() - Method in interface com.sun.grizzly.Context
Called by outer Threads that are not instances of WorkerThread to indicate that this Context should not be Context.recycle() or offered back to its pool.
incrementRefCount() - Method in class com.sun.grizzly.NIOContext
Called by outer Threads that are not instances of WorkerThread to indicate that this Context should not be NIOContext.recycle() or offered back to its pool.
inet - Variable in class com.sun.grizzly.TCPSelectorHandler
The inet address to use when binding.
initialByteBufferSize - Variable in class com.sun.grizzly.util.DefaultThreadPool
The initial ByteBuffer size for newly created WorkerThread instances
initOpRegistriesIfRequired() - Method in class com.sun.grizzly.TCPSelectorHandler
Initializes SelectionKey operation registries
injectToStringAttributes(StringBuilder) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
INPUT_BB - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
inputBB - Variable in class com.sun.grizzly.util.WorkerThread
The encrypted ByteBuffer used for handshaking and reading request bytes.
inputBBSize - Variable in class com.sun.grizzly.filter.SSLReadFilter
Encrypted ByteBuffer default size.
InputReader - Class in com.sun.grizzly.util
This class implement IO stream operations on top of a ByteBuffer.
InputReader() - Constructor for class com.sun.grizzly.util.InputReader
 
InputReader(ByteBuffer) - Constructor for class com.sun.grizzly.util.InputReader
 
InputReader.ChannelType - Enum in com.sun.grizzly.util
The Channel type is used to avoid invoking the instanceof operation when registering the Socket|Datagram Channel to the Selector.
inputStream - Variable in class com.sun.grizzly.UDPConnectorHandler
A blocking InputStream that use a pool of Selector to execute a blocking read operation.
instanceHandler - Variable in class com.sun.grizzly.Controller
The ProtocolChainInstanceHandler used by this instance.
instanceHandler - Variable in class com.sun.grizzly.TCPSelectorHandler
The ProtocolChainInstanceHandler used by this instance.
Interceptor<E,F extends Channel> - Interface in com.sun.grizzly.util
Simple interception hook used to trap events inside Grizzly core.
interupted(A) - Method in interface com.sun.grizzly.suspendable.SuspendableHandler
Invoked when a suspendable is cancelled (by calling Suspendable.cancel())
invokeAsyncQueueReader(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Invoke a AsyncQueueReader
invokeAsyncQueueWriter(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Invoke a AsyncQueueWriter
invokeCallbackHandler(CallbackHandler, Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Invoke a CallbackHandler via a Context instance.
invokeProtocolParser(Context, ProtocolParser) - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Invoke the ProtocolParser.
IOEvent<E> - Interface in com.sun.grizzly
When a non blocking operation occurs, the SelectorHandler implementation will invoke an instance of CallbackHandler with an instance of this class.
IOEvent.DefaultIOEvent<E> - Class in com.sun.grizzly
Simple IOEvent implementation
IOEvent.DefaultIOEvent(E) - Constructor for class com.sun.grizzly.IOEvent.DefaultIOEvent
 
isCancelled() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
isClientMode() - Method in class com.sun.grizzly.filter.SSLReadFilter
Returns true if the SSlEngine is set to use client mode when handshaking.
isClientMode() - Method in class com.sun.grizzly.SSLConfig
 
isCloned - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
isCloned() - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
isConnected() - Method in class com.sun.grizzly.SSLConnectorHandler
Is the underlying SocketChannel connected.
isConnected() - Method in class com.sun.grizzly.TCPConnectorHandler
Is the underlying SocketChannel connected.
isConnected - Variable in class com.sun.grizzly.UDPConnectorHandler
Is the connection established.
isConnected() - Method in class com.sun.grizzly.UDPConnectorHandler
Is the underlying DatagramChannel connected.
isConnectedLatch - Variable in class com.sun.grizzly.UDPConnectorHandler
IsConnected Latch related
isContinuousExecution() - Method in class com.sun.grizzly.DefaultProtocolChain
Return true if the current ExecutorService can re-execute its ProtocolFilter after a successful execution.
isContinuousExecution() - Method in class com.sun.grizzly.filter.ReadFilter
Return true if the current ExecutorService can re-execute its ProtocolFilter after a successful execution.
isContinuousExecution() - Method in interface com.sun.grizzly.ReinvokeAware
Return true if the current ExecutorService can re-execute its ProtocolFilter after a successful execution.
isDelegateToProtocolChain() - Method in class com.sun.grizzly.DefaultCallbackHandler
Return true> if delegation to the ProtocolChain is enabled.
isDone() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
isEmpty(K) - Method in class com.sun.grizzly.async.AsyncQueue
Checks if K key related queue is empty.
isExpectingMoreData() - Method in interface com.sun.grizzly.ProtocolParser
Is this ProtocolParser expecting more data ?
isHandleReadWriteConcurrently() - Method in class com.sun.grizzly.Controller
true if OP_ERAD and OP_WRITE can be handled concurrently.
isHandshakeDone() - Method in class com.sun.grizzly.SSLConnectorHandler
Is the underlying SocketChannel connected.
isLockEnabled() - Method in class com.sun.grizzly.util.StateHolder
Gets current locking mode
isNeedClientAuth() - Method in class com.sun.grizzly.filter.SSLReadFilter
Returns true if the SSLEngine will require client authentication.
isNeedClientAuth() - Method in class com.sun.grizzly.SSLConfig
 
isOpen() - Method in interface com.sun.grizzly.SelectorHandler
Is the underlying Selector open.
isOpen() - Method in class com.sun.grizzly.TCPSelectorHandler
Is the Selector open.
isReady(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
Checks whether AsyncQueueReader is registered for the SelectableChannel, associated with the given SelectionKey
isReady(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Checks whether there is any data in AsyncQueue ready to be written to the SelectableChannel, associated with the given SelectionKey
isReady(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueReader
Checks whether AsyncQueueReader is registered for the SelectableChannel, associated with the given SelectionKey
isReady(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Checks whether there is any data in AsyncQueue ready to be written to the SelectableChannel, associated with the given SelectionKey
isResumed() - Method in class com.sun.grizzly.suspendable.Suspendable
Return true if the connection associated with this instance has been #resumed
isReuseAddress() - Method in class com.sun.grizzly.TCPConnectorHandler
 
isReuseAddress() - Method in class com.sun.grizzly.TCPSelectorHandler
 
isRunInSeparateThread(Context.OpType) - Method in interface com.sun.grizzly.CallbackHandlerDescriptor
 
isSecure() - Method in class com.sun.grizzly.util.InputReader
Is this Stream secure.
isShutDown - Variable in class com.sun.grizzly.TCPSelectorHandler
Flag, which shows whether shutdown was called for this SelectorHandler
isSkipRead - Variable in class com.sun.grizzly.filter.ParserProtocolFilter
Should ParserProtocolFilter read the data from channel
isSkipRead() - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Method returns true, if this Filter perform channel read operation on execute, or false - Filter assumes the data was read by previous Filters in a chain.
isStarted() - Method in class com.sun.grizzly.Controller
Is this Controller started?
isSuspended() - Method in interface com.sun.grizzly.Context
Return true if this Context has been suspended by invoking suspend.
isSuspended() - Method in class com.sun.grizzly.NIOContext
Return true if this Context has been suspended by invoking suspend.
isTcpNoDelay() - Method in class com.sun.grizzly.TCPConnectorHandler
Return the tcpNoDelay value used by the underlying accepted Sockets.
isTcpNoDelay() - Method in class com.sun.grizzly.TCPSelectorHandler
Return the tcpNoDelay value used by the underlying accepted Sockets.
isTcpNoDelay() - Method in class com.sun.grizzly.UDPSelectorHandler
 
isWantClientAuth() - Method in class com.sun.grizzly.filter.SSLReadFilter
Returns true if the engine will request client authentication.
isWantClientAuth() - Method in class com.sun.grizzly.SSLConfig
 

K

key - Variable in class com.sun.grizzly.util.InputReader
The SelectionKey used by this stream.
KEY_STORE_FILE - Static variable in class com.sun.grizzly.SSLConfig
 
KEY_STORE_PASSWORD - Static variable in class com.sun.grizzly.SSLConfig
 
KEY_STORE_TYPE - Static variable in class com.sun.grizzly.SSLConfig
 
keyIsValid(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
keys() - Method in interface com.sun.grizzly.SelectorHandler
The SelectionKey that has been registered.
keys() - Method in class com.sun.grizzly.TCPSelectorHandler
Return the set of SelectionKey registered on this Selector.

L

Lifecycle - Interface in com.sun.grizzly
Simple Life cycle interface used to manage Grizzly component.
linger - Variable in class com.sun.grizzly.TCPConnectorHandler
The socket linger.
linger - Variable in class com.sun.grizzly.TCPSelectorHandler
The socket linger.
listener - Variable in class com.sun.grizzly.util.StateHolder.ConditionListener
 
locallyClosed(SelectionKey) - Method in interface com.sun.grizzly.util.ConnectionCloseHandler
Invoked when the a SelectionKey is cancelled locally, e.g. by one SelectorHandler, ConnectionHandler or SelectionKeyHandler
log(String, Throwable) - Method in class com.sun.grizzly.filter.ReadFilter
Log a message/exception.
log(String, Throwable) - Static method in class com.sun.grizzly.filter.SSLReadFilter
Log a message/exception.
log(String, Throwable) - Method in class com.sun.grizzly.filter.UDPWriteFilter
Log a message/exception.
LogFilter - Class in com.sun.grizzly.filter
Simple filter that log that output the bytes read.
LogFilter() - Constructor for class com.sun.grizzly.filter.LogFilter
 
logger - Variable in class com.sun.grizzly.BaseSelectionKeyHandler
 
logger - Variable in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
logger - Static variable in class com.sun.grizzly.Controller
Default Logger.
logger() - Static method in class com.sun.grizzly.Controller
Return the current Logger used by this Controller.
logger - Variable in class com.sun.grizzly.TCPSelectorHandler
 
LoggingFormatter - Class in com.sun.grizzly.util
Format the record to include the Thread that logged the record.
LoggingFormatter() - Constructor for class com.sun.grizzly.util.LoggingFormatter
 

M

main(String[]) - Static method in class com.sun.grizzly.util.LoggingFormatter
Example to test the com.sun.grizzly.util.LoggingFormatter You need to include this parameter in the command line -Djava.util.logging.config.file=myfile
makeBlockingConcurrentQueue() - Static method in class com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueueFactory
Create a ConcurrentQueue whose implementation uses conventional locking to protect the data structure.
makeBlockingInboundConnectionCache(String, int, int, Logger) - Static method in class com.sun.grizzly.connectioncache.spi.transport.ConnectionCacheFactory
 
makeBlockingOutboundConnectionCache(String, int, int, int, Logger) - Static method in class com.sun.grizzly.connectioncache.spi.transport.ConnectionCacheFactory
 
makeConcurrentQueue() - Static method in class com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueueFactory
Create a ConcurrentQueue that does no locking at all.
markSupported() - Method in class com.sun.grizzly.util.InputReader
Return true if mark is supported.
MAX_BB_SIZE - Static variable in class com.sun.grizzly.util.SSLUtils
The maximum size a ByteBuffer can take.
maxParallelConnections() - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
maxParallelConnections() - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Configured maximum number of connections supported per ContactInfo.
maxTasksCount - Variable in class com.sun.grizzly.util.DefaultThreadPool
 
MESSAGE - Static variable in interface com.sun.grizzly.ProtocolParser
Holds the message returned from getNextMessage for use by downstream filters
multiReadThreadSelectorHandler - Variable in class com.sun.grizzly.Controller
The SelectorHandler, which will manage connection accept, if readThreadsCount > 0 and spread connection processing between different read threads

N

name - Variable in class com.sun.grizzly.util.DefaultThreadPool
 
newInstance() - Method in class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler
 
newInstance() - Method in class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueDelegateCIH
 
newInstance() - Method in class com.sun.grizzly.util.ConcurrentLinkedQueuePool
 
newProtocolParser() - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Return a new or cached ProtocolParser instance.
newSSLEngine() - Method in class com.sun.grizzly.filter.SSLReadFilter
Return a new configuredSSLEngine
newThread(Runnable) - Method in class com.sun.grizzly.util.WorkerThreadFactory
Create a new WorkerThread.
nextKeysExpiration - Variable in class com.sun.grizzly.DefaultSelectionKeyHandler
Next time the exprireKeys() will delete keys.
NIOContext - Class in com.sun.grizzly
This Object is used to share information between the Grizzly Framework classes and ProtocolFilter implementation.
NIOContext() - Constructor for class com.sun.grizzly.NIOContext
Constructor
notificationObject - Variable in class com.sun.grizzly.util.StateHolder.EventListener
 
notifyEvent() - Method in class com.sun.grizzly.util.StateHolder.EventListener
 
notifyException(Throwable) - Method in class com.sun.grizzly.Controller
Notify exception occured
notifyException(DefaultProtocolChain.Phase, ProtocolFilter, Throwable) - Method in class com.sun.grizzly.DefaultProtocolChain
Notifies all DefaultProtocolChain.EventHandlers about exception, which occured
notifyListener() - Method in class com.sun.grizzly.util.StateHolder.ConditionListener
 
notifyListener(Object) - Static method in class com.sun.grizzly.util.StateHolder.EventListener
 
notifyReady() - Method in class com.sun.grizzly.Controller
Notify controller is ready
notifyRemotlyClose(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Notify a ConnectionCloseHandler that a remote connection has been closed.
notifyResult() - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
notifyStarted() - Method in class com.sun.grizzly.Controller
Notify controller started
notifyStopped() - Method in class com.sun.grizzly.Controller
Notify controller stopped
notifyWhenConditionMatchState(StateHolder.ConditionListener<E>) - Method in class com.sun.grizzly.util.StateHolder
Register custom condition listener, which will be notified, when listener's condition will become true.
notifyWhenStateIsEqual(E, Object) - Method in class com.sun.grizzly.util.StateHolder
Register listener, which will be notified, when state will be equal to passed one.
notifyWhenStateIsNotEqual(E, Object) - Method in class com.sun.grizzly.util.StateHolder
Register listener, which will be notified, when state will become not equal to passed one.
numberOfBusyConnections() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Number of non-idle connections.
numberOfConnections() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Total number of connections currently managed by the cache.
numberOfIdleConnections() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Number of idle connections; that is, connections for which the number of get/release or responseReceived/responseProcessed calls are equal.
numberOfReclaimableConnections() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Number of idle connections that are reclaimable.
numberToReclaim() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
numberToReclaim() - Method in interface com.sun.grizzly.connectioncache.spi.transport.ConnectionCache
Number of connections to reclaim each time reclamation starts.

O

ObjectPool<E> - Interface in com.sun.grizzly.util
Basic interface for object pool implementations
obtainAsyncQueueEntry(K) - Method in class com.sun.grizzly.async.AsyncQueue
 
obtainSSLEngine(SelectionKey) - Method in class com.sun.grizzly.filter.SSLReadFilter
Configure and return an instance of SSLEngine
offer(K, E) - Method in class com.sun.grizzly.async.AsyncQueue
Add data to the AsyncQueue, corresponding to the given E key
offer(AsyncQueueReaderContextTask) - Static method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
offer() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
offer(AsyncQueueWriterContextTask) - Static method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
offer() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
offer(CallbackHandlerContextTask) - Static method in class com.sun.grizzly.CallbackHandlerContextTask
 
offer() - Method in class com.sun.grizzly.CallbackHandlerContextTask
 
offer(V) - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueBlockingImpl
Add a new element to the tail of the queue.
offer(V) - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueImpl
Add a new element to the tail of the queue.
offer(V) - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueNonBlockingImpl
Add a new element to the tail of the queue.
offer(V) - Method in interface com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueue
Add a new element to the tail of the queue.
offer() - Method in class com.sun.grizzly.ContextTask
Return instance to the pool WARN: Do not call super.offer(), as it can lead to multiple offer call
offer(E) - Method in class com.sun.grizzly.ContextTask.TaskPool
 
offer(ProtocolChain) - Method in class com.sun.grizzly.DefaultProtocolChainInstanceHandler
Offer (add) an instance of ProtocolChain to this instance pool.
offer(ProtocolChainContextTask) - Static method in class com.sun.grizzly.ProtocolChainContextTask
 
offer() - Method in class com.sun.grizzly.ProtocolChainContextTask
 
offer(ProtocolChain) - Method in interface com.sun.grizzly.ProtocolChainInstanceHandler
Pool an instance of ProtocolChain.
offer(ProtocolChain) - Method in class com.sun.grizzly.SingleProtocolChainInstanceHandler
Offer (add) an instance of ProtocolChain to this instance pool.
offer(E) - Method in class com.sun.grizzly.util.ConcurrentLinkedQueuePool
 
offer(E) - Method in interface com.sun.grizzly.util.ObjectPool
 
onAcceptInterest(SelectionKey, Context) - Method in class com.sun.grizzly.RoundRobinSelectorHandler
 
onAcceptInterest(SelectionKey, Context) - Method in interface com.sun.grizzly.SelectorHandler
Handle OP_ACCEPT.
onAcceptInterest(SelectionKey, Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle OP_ACCEPT.
onAcceptInterest(SelectionKey, Context) - Method in class com.sun.grizzly.UDPSelectorHandler
Handle OP_ACCEPT.
onClose(SelectableChannel) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
Callback method, which should be called by SelectorHandler to notify, that given SelectableChannel is going to be closed, so related data could be released from AsyncQueueReader
onClose(SelectableChannel) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Callback method, which should be called by SelectorHandler to notify, that given SelectableChannel is going to be closed, so related SelectableChannel data could be released from AsyncQueue
onClose(SelectableChannel) - Method in interface com.sun.grizzly.async.AsyncQueueReader
Callback method, which should be called by SelectorHandler to notify, that given SelectableChannel is going to be closed, so related data could be released from AsyncQueueReader
onClose(SelectableChannel) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Callback method, which should be called by SelectorHandler to notify, that given SelectableChannel is going to be closed, so related SelectableChannel data could be released from AsyncQueue
onConnect(IOEvent<E>) - Method in interface com.sun.grizzly.CallbackHandler
This method is called when an non blocking OP_CONNECT is ready to get processed.
onConnect(IOEvent) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
onConnect(IOEvent<Context>) - Method in class com.sun.grizzly.DefaultCallbackHandler
Execute the non blocking connect operation.
onConnectInterest(SelectionKey, Context) - Method in interface com.sun.grizzly.SelectorHandler
Handle OP_CONNECT.
onConnectInterest(SelectionKey, Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle OP_CONNECT.
onConnectOp(Context, SelectionKeyOP.ConnectSelectionKeyOP) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle new OP_CONNECT ops.
onConnectOp(Context, SelectionKeyOP.ConnectSelectionKeyOP) - Method in class com.sun.grizzly.UDPSelectorHandler
Handle new OP_CONNECT ops.
onException(Exception, SelectionKey, ByteBuffer, Queue<AsyncQueueReadUnit>) - Method in interface com.sun.grizzly.async.AsyncReadCallbackHandler
Method will be called by AsyncQueueReader, if error occured when reading from the SelectableChannel, which is associated with SelectionKey
onException(Exception, SelectionKey, ByteBuffer, Queue<AsyncQueueWriteUnit>) - Method in interface com.sun.grizzly.async.AsyncWriteCallbackHandler
Method will be called by AsyncQueueWriter, if error occured when writing ByteBuffer to the SelectableChannel, associated with SelectionKey
onException(Throwable) - Method in interface com.sun.grizzly.ControllerStateListener
Notification: Exception occured during Controller thread execution
onException(Throwable) - Method in class com.sun.grizzly.ControllerStateListenerAdapter
 
onException(DefaultProtocolChain.Phase, ProtocolFilter, Throwable) - Method in interface com.sun.grizzly.DefaultProtocolChain.EventHandler
 
onHandshake(IOEvent<Context>) - Method in class com.sun.grizzly.DefaultCallbackHandler
By default, do nothing.
onHandshake(IOEvent<E>) - Method in interface com.sun.grizzly.SSLCallbackHandler
This method is called when an non blocking OP_CONNECT is ready to get processed.
onRead(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
Callback method, which should be called by SelectorHandler to notify, that SelectableChannel, associated with the given SelectableChannel has ready data for reading.
onRead(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueReader
Callback method, which should be called by SelectorHandler to notify, that SelectableChannel, associated with the given SelectableChannel has ready data for reading.
onRead(IOEvent<E>) - Method in interface com.sun.grizzly.CallbackHandler
This method is called when an non blocking OP_READ is ready to get processed.
onRead(IOEvent) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
onRead(IOEvent<Context>) - Method in class com.sun.grizzly.DefaultCallbackHandler
Delegate the processing of the read operation to the IOEvent{ associated {@link ProtocolChain}
onReadCompleted(SelectionKey, SocketAddress, AsyncQueueReadUnit) - Method in interface com.sun.grizzly.async.AsyncReadCallbackHandler
Method will be called by AsyncQueueReader, if data was read to the ByteBuffer from the SelectableChannel, associated with SelectionKey, and read data confirms to the user-specific condition (if any was set).
onReadInterest(SelectionKey, Context) - Method in interface com.sun.grizzly.SelectorHandler
Handle OP_READ.
onReadInterest(SelectionKey, Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle OP_READ.
onReadOp(SelectionKeyOP) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle new OP_READ ops.
onReady() - Method in interface com.sun.grizzly.ControllerStateListener
Notification: Controller is ready to process connections; SelectorHandlers were initialized
onReady() - Method in class com.sun.grizzly.ControllerStateListenerAdapter
 
onStarted() - Method in interface com.sun.grizzly.ControllerStateListener
Nofitication: Controller was started, thread pool was initialized
onStarted() - Method in class com.sun.grizzly.ControllerStateListenerAdapter
 
onStopped() - Method in interface com.sun.grizzly.ControllerStateListener
Notification: Controller was stopped, all worker threads were stopped
onStopped() - Method in class com.sun.grizzly.ControllerStateListenerAdapter
 
onWrite(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Callback method, which should be called by SelectorHandler to notify, that SelectableChannel, associated with the given SelectionKey is ready to transmit data.
onWrite(SelectionKey) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Callback method, which should be called by SelectorHandler to notify, that SelectableChannel, associated with the given SelectionKey is ready to transmit data.
onWrite(IOEvent<E>) - Method in interface com.sun.grizzly.CallbackHandler
This method is called when an non blocking OP_WRITE is ready to get processed.
onWrite(IOEvent) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
onWrite(IOEvent<Context>) - Method in class com.sun.grizzly.DefaultCallbackHandler
Delegate the processing of the write operation to the IOEvent{ associated {@link ProtocolChain}
onWriteCompleted(SelectionKey, AsyncQueueWriteUnit) - Method in interface com.sun.grizzly.async.AsyncWriteCallbackHandler
Method will be called by AsyncQueueWriter, if whole ByteBuffer data was written to the SelectableChannel, associated with SelectionKey
onWriteInterest(SelectionKey, Context) - Method in interface com.sun.grizzly.SelectorHandler
Handle OP_WRITE.
onWriteInterest(SelectionKey, Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle OP_WRITE.
onWriteOp(SelectionKeyOP) - Method in class com.sun.grizzly.TCPSelectorHandler
Handle new OP_WRITE ops.
OperationResult - Class in com.sun.grizzly.async
Class represents the result of a single I/O operation on async queue.
OperationResult() - Constructor for class com.sun.grizzly.async.OperationResult
 
opToRegister - Variable in class com.sun.grizzly.TCPSelectorHandler
The list of SelectionKeyOP to register next time the Selector.select is invoked.
OutboundConnectionCache<C extends Closeable> - Interface in com.sun.grizzly.connectioncache.spi.transport
A concurrent mostly non-blocking connection cache.
OutboundConnectionCacheBlockingImpl<C extends Closeable> - Class in com.sun.grizzly.connectioncache.impl.transport
 
OutboundConnectionCacheBlockingImpl(String, int, int, int, Logger) - Constructor for class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
OUTPUT_BB - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
outputBB - Variable in class com.sun.grizzly.util.WorkerThread
The encrypted ByteBuffer used for handshaking and writing response bytes.
OutputWriter - Class in com.sun.grizzly.util
NIO utility to flush ByteBuffer
OutputWriter() - Constructor for class com.sun.grizzly.util.OutputWriter
 

P

parse(ByteBuffer) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Parse the ByteBuffer and try to determine if the bytes stream has been fully read from the SocketChannel.
PARSER - Static variable in interface com.sun.grizzly.ProtocolParser
Used to associate a particular parser with a connection
ParserProtocolFilter - Class in com.sun.grizzly.filter
Simple ProtocolFilter implementation which read the available bytes and delegate the decision of reading more bytes or not to a ProtocolParser.
ParserProtocolFilter() - Constructor for class com.sun.grizzly.filter.ParserProtocolFilter
 
pause() - Method in class com.sun.grizzly.Controller
Pause this Controller and associated SelectorHandlers
pause() - Method in interface com.sun.grizzly.Lifecycle
Pause this Lifecycle.
pause() - Method in interface com.sun.grizzly.SelectorHandler
Pause this SelectorHandler
pause() - Method in class com.sun.grizzly.TCPSelectorHandler
Pause this SelectorHandler
peek(K) - Method in class com.sun.grizzly.async.AsyncQueue
Get head element of E key related queue.
poll(K) - Method in class com.sun.grizzly.async.AsyncQueue
Get head element of K key related queue.
poll() - Static method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
poll() - Static method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
poll() - Static method in class com.sun.grizzly.CallbackHandlerContextTask
 
poll() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueBlockingImpl
Return an element from the head of the queue.
poll() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueImpl
Return an element from the head of the queue.
poll() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueNonBlockingImpl
Return an element from the head of the queue.
poll() - Method in interface com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueue
Return an element from the head of the queue.
poll() - Method in class com.sun.grizzly.DefaultProtocolChainInstanceHandler
Return a pooled instance of ProtocolChain.
poll() - Static method in class com.sun.grizzly.ProtocolChainContextTask
 
poll() - Method in interface com.sun.grizzly.ProtocolChainInstanceHandler
Return an instance of ProtocolChain.
poll() - Method in class com.sun.grizzly.SingleProtocolChainInstanceHandler
Return a ProtocolChain instance.
poll() - Method in class com.sun.grizzly.util.ConcurrentLinkedQueuePool
 
poll() - Method in interface com.sun.grizzly.util.ObjectPool
 
pollContext(SelectionKey) - Method in class com.sun.grizzly.Controller
Get an instance of a Context
pollContext(SelectionKey, Context.OpType) - Method in class com.sun.grizzly.Controller
Get an instance of a Context
pollContext(Context, SelectionKey, Context.OpType) - Method in class com.sun.grizzly.TCPSelectorHandler
Polls Context from pool and initializes it.
port - Variable in class com.sun.grizzly.TCPSelectorHandler
The default TCP port.
postExecute(Context) - Method in class com.sun.grizzly.filter.EchoAsyncWriteQueueFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.EchoFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.LogFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.ParserProtocolFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.ReadFilter
If no bytes were available, close the connection by cancelling the SelectionKey.
postExecute(Context) - Method in class com.sun.grizzly.filter.SSLEchoAsyncWriteQueueFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.SSLEchoFilter
 
postExecute(Context) - Method in class com.sun.grizzly.filter.SSLReadFilter
If no bytes were available, close the connection by cancelling the SelectionKey.
postExecute(Context) - Method in class com.sun.grizzly.filter.UDPWriteFilter
Re-enable the SelectionKey and make sure the ByteBuffer has been cleared.
postExecute(Context) - Method in interface com.sun.grizzly.ProtocolFilter
Execute any cleanup activities, such as releasing resources that were acquired during the execute() method of this ProtocolFilter instance.
postExecute(Context) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Excute the pattern matching algorithm to determine if a the current connection must be suspended or not, and when.
postExecuteProtocolFilter(int, Context) - Method in class com.sun.grizzly.DefaultProtocolChain
Execute the ProtocolFilter.postExcute.
postParse(ByteBuffer) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. After parsing the bytes, post process the ByteBuffer
postProcess(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
SelectionKey post process notification
postProcess(SelectionKey) - Method in class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
 
postProcess(SelectionKey) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
SelectionKey post process notification
postProcess(SelectionKey) - Method in interface com.sun.grizzly.SelectionKeyHandler
SelectionKey post process notification
postProcess(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyActionAttachment
 
postProcess(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
postProcess(SelectionKey) - Method in class com.sun.grizzly.util.ThreadAttachment
SelectionKey attachment postProcessing
postSelect(Context) - Method in interface com.sun.grizzly.SelectorHandler
This method is garantee to always be called after operation Selector.select().
postSelect(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Invoked after Selector.select().
preParse(ByteBuffer) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Before parsing the bytes, initialize and prepare the algorithm.
preSelect(Context) - Method in interface com.sun.grizzly.SelectorHandler
This method is garantee to always be called before operation Selector.select().
preSelect(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Before invoking Selector.select(long), make sure the ServerSocketChannel has been created.
preSelect(Context) - Method in class com.sun.grizzly.UDPSelectorHandler
Before invoking Selector.select(), make sure the ServerScoketChannel has been created.
priority - Variable in class com.sun.grizzly.util.DefaultThreadPool
Threads priority
process(ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncQueueDataProcessor
Method is called to process data.
process(SelectionKey) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
SelectionKey process notification
process(SelectionKey) - Method in class com.sun.grizzly.connectioncache.server.CacheableSelectionKeyHandler
 
process(SelectionKey) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
SelectionKey process notification
process(SelectionKey) - Method in interface com.sun.grizzly.SelectionKeyHandler
SelectionKey process notification
process(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyActionAttachment
 
process(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
process(SelectionKey) - Method in class com.sun.grizzly.util.ThreadAttachment
SelectionKey attachment processing
processedDataSize - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
processedElementsCount - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
processPendingOperations(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
 
processTask(Callable) - Method in class com.sun.grizzly.util.WorkerThreadImpl
Processes the given task.
protocol() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
protocol() - Method in interface com.sun.grizzly.ConnectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in interface com.sun.grizzly.SelectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in class com.sun.grizzly.SSLConnectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in class com.sun.grizzly.SSLSelectorHandler
 
protocol() - Method in class com.sun.grizzly.TCPConnectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in class com.sun.grizzly.TCPSelectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in class com.sun.grizzly.UDPConnectorHandler
A token decribing the protocol supported by an implementation of this interface
protocol() - Method in class com.sun.grizzly.UDPSelectorHandler
A token describing the protocol supported by an implementation of this interface
PROTOCOL_CHAIN_POST_INSTRUCTION - Static variable in interface com.sun.grizzly.ProtocolChain
ProtocolChain result attribute name.
ProtocolChain - Interface in com.sun.grizzly
This class implement the "Chain of Responsibility" pattern (for more info, take a look at the classic "Gang of Four" design patterns book).
protocolChain - Variable in class com.sun.grizzly.SingleProtocolChainInstanceHandler
Single ProtocolChain instance.
ProtocolChainContextTask - Class in com.sun.grizzly
ProtocolChain task, which will be executed by Context, when Context.execute(ContextTask) is called.
ProtocolChainContextTask() - Constructor for class com.sun.grizzly.ProtocolChainContextTask
 
ProtocolChainInstanceHandler - Interface in com.sun.grizzly
An ProtocolChainInstanceHandler is where one or several ProtocolChain are created and cached.
ProtocolChainInstruction - Enum in com.sun.grizzly
The ProtocolChainInstruction contains the instruction for a ProtocolChain, how it should continue the invokation.
protocolChains - Variable in class com.sun.grizzly.DefaultProtocolChainInstanceHandler
List used to cache instance of ProtocolChain.
ProtocolFilter - Interface in com.sun.grizzly
A ProtocolFilter 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 ProtocolContext.
protocolFilters - Variable in class com.sun.grizzly.DefaultProtocolChain
The list of ProtocolFilter this chain will invoke.
ProtocolParser<T> - Interface in com.sun.grizzly
An interface that knows how to parse bytes into a protocol data unit.
publish(Properties) - Method in class com.sun.grizzly.SSLConfig
 

Q

queue - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
queuedActionLock - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
queuedElementsCount - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 

R

read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.async.AbstractAsyncQueueReader
read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueReader
 
read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in interface com.sun.grizzly.async.AsyncQueueReader
 
read(SelectionKey, ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueReader
 
read(ByteBuffer, boolean) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
read(ByteBuffer, boolean) - Method in interface com.sun.grizzly.ConnectorHandler
Read bytes.
read(ByteBuffer, boolean) - Method in class com.sun.grizzly.SSLConnectorHandler
Read bytes.
read(ByteBuffer, boolean) - Method in class com.sun.grizzly.TCPConnectorHandler
Read bytes.
read(ByteBuffer, boolean) - Method in class com.sun.grizzly.UDPConnectorHandler
Read bytes.
read() - Method in class com.sun.grizzly.util.InputReader
Read the first byte from the wrapped ByteBuffer.
read(byte[]) - Method in class com.sun.grizzly.util.InputReader
Read the bytes from the wrapped ByteBuffer.
read(byte[], int, int) - Method in class com.sun.grizzly.util.InputReader
Read the first byte of the wrapped ByteBuffer.
read(ByteBuffer) - Method in class com.sun.grizzly.util.InputReader
Read the bytes of the wrapped ByteBuffer.
readAttempts - Variable in class com.sun.grizzly.filter.ReadFilter
 
ReadController - Class in com.sun.grizzly
ReadController class represents Controller, which is not itself independent.
ReadController() - Constructor for class com.sun.grizzly.ReadController
 
ReadFilter - Class in com.sun.grizzly.filter
Simple ProtocolFilter implementation which read the available bytes and delegate the processing to the next ProtocolFilter in the ProtocolChain.
ReadFilter() - Constructor for class com.sun.grizzly.filter.ReadFilter
 
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueReadable
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in interface com.sun.grizzly.async.AsyncQueueReadable
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueReadable
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in class com.sun.grizzly.SSLConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.SSLConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in class com.sun.grizzly.TCPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.TCPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition) - Method in class com.sun.grizzly.UDPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readFromAsyncQueue(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.UDPConnectorHandler
Method reads data to the ByteBuffer using async read queue.
readPostProcessor - Variable in class com.sun.grizzly.async.AsyncQueueReadUnit
 
readThreadControllers - Variable in class com.sun.grizzly.Controller
The array of Controllers to be used for reading
readThreadsCount - Variable in class com.sun.grizzly.Controller
The number of read threads
readTimeout - Variable in class com.sun.grizzly.util.InputReader
The time to wait before timing out when reading bytes
readWithTemporarySelector(SelectableChannel, ByteBuffer, long) - Static method in class com.sun.grizzly.util.Utils
Method reads data from SelectableChannel to ByteBuffer.
readySelectorHandlerCounter - Variable in class com.sun.grizzly.Controller
Internal countdown counter of SelectorHandlers, which are ready to process
receive(ByteBuffer) - Method in class com.sun.grizzly.UDPConnectorHandler
Receive bytes.
reclaim() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
Reclaim some idle cached connections.
reclaimableConnections - Variable in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
recycle() - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
recycle() - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
recycle() - Method in class com.sun.grizzly.CallbackHandlerContextTask
 
recycle() - Method in interface com.sun.grizzly.Context
Recycle this instance.
recycle() - Method in class com.sun.grizzly.ContextTask
 
recycle() - Method in class com.sun.grizzly.NIOContext
Recycle this instance.
recycle() - Method in class com.sun.grizzly.util.InputReader
Recycle this object.
recycle() - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
recycle() - Method in class com.sun.grizzly.util.SelectionKeyOP
 
recycle() - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Recycle the algorithm.
register(SelectionKey, long) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Deprecated.  
register(SelectionKey, int) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Register a SelectionKey on Selector.
register(SelectableChannel, int) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Register a SelectableChannel on Selector.
register(Iterator<SelectionKey>, int) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Register a set of SelectionKeys.
register(Iterator<SelectionKey>, int) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Register a set of SelectionKeys.
register(SelectionKey, int) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Register a SelectionKey on Selector.
register(SelectableChannel, int) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Register a SelectableChannel on Selector.
register(SelectionKey, long) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
Attach a times out to the SelectionKey used to cancel idle connection.
register(SelectionKey, long) - Method in interface com.sun.grizzly.SelectionKeyHandler
Deprecated.  
register(SelectionKey, int) - Method in interface com.sun.grizzly.SelectionKeyHandler
Register a SelectionKey on Selector.
register(SelectableChannel, int) - Method in interface com.sun.grizzly.SelectionKeyHandler
Register a SelectableChannel on Selector.
register(Iterator<SelectionKey>, int) - Method in interface com.sun.grizzly.SelectionKeyHandler
Register a set of SelectionKeys.
register(SelectableChannel, int) - Method in interface com.sun.grizzly.SelectorHandler
Register the SelectableChannel on the Selector.
register(SelectionKey, int) - Method in interface com.sun.grizzly.SelectorHandler
Register the SelectionKey on the Selector.
register(SelectionKey, int) - Method in class com.sun.grizzly.TCPSelectorHandler
Register a SelectionKey to this Selector.
register(SelectableChannel, int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
registerForWriting(SelectionKey) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
 
registerKey(SelectionKey) - Method in class com.sun.grizzly.Controller
Register a SelectionKey.
registerKey(SelectionKey, int) - Method in class com.sun.grizzly.Controller
Register a SelectionKey on the first SelectorHandler that was added using the addSelectorHandler().
registerKey(SelectionKey, int, Controller.Protocol) - Method in class com.sun.grizzly.Controller
Register a SelectionKey.
reimburseSelector() - Static method in class com.sun.grizzly.util.SelectorFactory
Add Selector to the cache.
ReinvokeAware - Interface in com.sun.grizzly
The common interface, for objects, which could have influence on a ProtocolChain reinvokation.
release(int) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
Releases underlying connection, which means it could be reused for writing by other CacheableConnectorHandler, however this CacheableConnectorHandler will be still interested in getting expectedResponseCount responses on it.
release(C, int) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
release(C, int) - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Release a Connection previously obtained from get.
release(E) - Method in class com.sun.grizzly.ConnectorInstanceHandler.ConcurrentQueueConnectorInstanceHandler
Release a ConnectorHandler
release(E) - Method in interface com.sun.grizzly.ConnectorInstanceHandler
Release a ConnectorHandler
release(SelectionKey) - Method in class com.sun.grizzly.util.CallbackHandlerSelectionKeyAttachment
 
release(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyAttachment
 
release(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
release(SelectionKey) - Method in class com.sun.grizzly.util.ThreadAttachment
 
releaseBuffer() - Method in interface com.sun.grizzly.ProtocolParser
No more parsing will be done on the buffer passed to ProtocolParser#startBuffer().
releaseConnectorHandler(CacheableConnectorHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandlerPool
 
releaseConnectorHandler(E) - Method in interface com.sun.grizzly.ConnectorHandlerPool
Release a ConnectorHandler.
releaseConnectorHandler(ConnectorHandler) - Method in class com.sun.grizzly.Controller
Return a ConnectorHandler to the pool of ConnectorHandler.
releaseConnectorHandler(ConnectorHandler) - Method in class com.sun.grizzly.DefaultConnectorHandlerPool
 
releaseConnectorHandler(ConnectorHandler) - Method in interface com.sun.grizzly.SelectorHandler
Release a ConnectorHandler.
releaseConnectorHandler(ConnectorHandler) - Method in class com.sun.grizzly.TCPSelectorHandler
Release a ConnectorHandler.
releaseSelectionKeyOP(SelectionKeyOP) - Static method in class com.sun.grizzly.util.SelectionKeyOP
 
remotlyClosed(SelectionKey) - Method in interface com.sun.grizzly.util.ConnectionCloseHandler
Invoked when a remote connection is being closed.
remove() - Method in interface com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueue.Handle
Delete the element corresponding to this handle from the queue.
removeAttribute(String) - Method in interface com.sun.grizzly.Context
Remove a key/value object.
removeAttribute(String) - Method in class com.sun.grizzly.Controller
Remove a key/value object.
removeAttribute(String) - Method in class com.sun.grizzly.NIOContext
Remove a key/value object.
removeAttribute(String) - Method in class com.sun.grizzly.TCPSelectorHandler
Remove a key/value object.
removeAttribute(String) - Method in interface com.sun.grizzly.util.AttributeHolder
Remove a name/value object.
removeAttribute(String) - Method in class com.sun.grizzly.util.ThreadAttachment
 
removeConditionListener(StateHolder.ConditionListener<E>) - Method in class com.sun.grizzly.util.StateHolder
 
removeEntry(K) - Method in class com.sun.grizzly.async.AsyncQueue
Remove head element of K key related queue.
removeEventHandler(DefaultProtocolChain.EventHandler) - Method in class com.sun.grizzly.DefaultProtocolChain
Remove the DefaultProtocolChain.EventHandler.
removeFilter(ProtocolFilter) - Method in class com.sun.grizzly.DefaultProtocolChain
Remove a ProtocolFilter.
removeFilter(ProtocolFilter) - Method in interface com.sun.grizzly.ProtocolChain
Remove the ProtocolFilter from this chain.
removeSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.Controller
Shuts down SelectorHandler and removes it from this Controller list
removeSelectorHandlerClone(SelectorHandler) - Method in class com.sun.grizzly.ReadController
Removes SelectorHandler's clone, registered on thisReadController
removeStateListener(ControllerStateListener) - Method in class com.sun.grizzly.Controller
Remove controller state listener
REQUEST_BUFFERED - Static variable in interface com.sun.grizzly.util.Interceptor
The request has been buffered.
REQUEST_LINE_PARSED - Static variable in interface com.sun.grizzly.util.Interceptor
The request line has been parsed
requestProcessed(C, int) - Method in class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
 
requestProcessed(C, int) - Method in interface com.sun.grizzly.connectioncache.spi.transport.InboundConnectionCache
Indicate that request processing has been completed for a request received on conn.
requestReceived(C) - Method in class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
 
requestReceived(C) - Method in interface com.sun.grizzly.connectioncache.spi.transport.InboundConnectionCache
Mark a connection as busy because a request is being processed on the connection.
reset() - Method in class com.sun.grizzly.util.ThreadAttachment
 
reset() - Method in class com.sun.grizzly.util.WorkerThread
 
reset() - Method in class com.sun.grizzly.util.WorkerThreadImpl
 
RESPONSE_PROCEEDED - Static variable in interface com.sun.grizzly.util.Interceptor
The response has been proceeded.
responseReceived() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
Notifies connection cache, that response was received.
responseReceived(C) - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
Decrement the number of expected responses.
responseReceived(C) - Method in interface com.sun.grizzly.connectioncache.spi.transport.OutboundConnectionCache
Inform the cache that a response has been received on a particular connection.
responseSent(C) - Method in class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
Decrement the number of expected responses.
responseSent(C) - Method in interface com.sun.grizzly.connectioncache.spi.transport.InboundConnectionCache
Inform the cache that a response has been sent on a particular connection.
resume() - Method in interface com.sun.grizzly.Context
Resume a Context.suspend()ed Context.
resume() - Method in class com.sun.grizzly.Controller
Resume this Controller and associated SelectorHandlers
resume() - Method in interface com.sun.grizzly.Lifecycle
Resume this Lifecycle.
resume() - Method in class com.sun.grizzly.NIOContext
Resume a NIOContext.suspend()ed Context.
resume() - Method in interface com.sun.grizzly.SelectorHandler
Resume this SelectorHandler
resume() - Method in class com.sun.grizzly.suspendable.Suspendable
Resume a suspended connection.
resume(SelectionKey) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Resume the connection by register back the SelectionKey for OP event.
resume() - Method in class com.sun.grizzly.TCPSelectorHandler
Resume this SelectorHandler
resumed(A) - Method in interface com.sun.grizzly.suspendable.SuspendableHandler
Invoked when a suspendable is resumed (by calling Suspendable.resume())
retrieve(Properties) - Method in class com.sun.grizzly.SSLConfig
 
returnContext(Context) - Method in class com.sun.grizzly.Controller
Return a Context to its pool if it is not shared.
returnSelector(Selector) - Static method in class com.sun.grizzly.util.SelectorFactory
Return the Selector to the cache
reuseAddress - Variable in class com.sun.grizzly.TCPConnectorHandler
The socket reuseAddress
reuseAddress - Variable in class com.sun.grizzly.TCPSelectorHandler
The socket reuseAddress
Role - Enum in com.sun.grizzly
The transport role
role - Variable in class com.sun.grizzly.TCPSelectorHandler
Is this used for client only or client/server operation.
rollbackParseState(ByteBuffer) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Rollback the ByteBuffer to its previous state in case an error as occured.
RoundRobinSelectorHandler - Class in com.sun.grizzly
A SelectorHandler handles all java.nio.channels.Selector operations.
RoundRobinSelectorHandler() - Constructor for class com.sun.grizzly.RoundRobinSelectorHandler
 
RoundRobinSelectorHandler(ReadController[]) - Constructor for class com.sun.grizzly.RoundRobinSelectorHandler
 
run() - Method in class com.sun.grizzly.Controller
Execute this Controller.
run() - Method in class com.sun.grizzly.SelectorHandlerRunner
 

S

SECURE_BUFFERS - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
select(Context) - Method in interface com.sun.grizzly.SelectorHandler
Invoke the Selector.select() method.
select(Context) - Method in class com.sun.grizzly.TCPSelectorHandler
Execute the Selector.select(...) operations.
SelectionKeyActionAttachment - Class in com.sun.grizzly.util
Class represents extended version of SelectionKeyAttachment, and introduces process method, which will be called by framework once SelectionKey has some ready event, before actual event processing.
SelectionKeyActionAttachment() - Constructor for class com.sun.grizzly.util.SelectionKeyActionAttachment
 
SelectionKeyAttachment - Class in com.sun.grizzly.util
Basic class for all SelectionKey attachments.
SelectionKeyAttachment() - Constructor for class com.sun.grizzly.util.SelectionKeyAttachment
 
SelectionKeyAttachmentWrapper<E> - Class in com.sun.grizzly.util
SelectionKey attachment utility class.
SelectionKeyAttachmentWrapper() - Constructor for class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
SelectionKeyContextTask - Class in com.sun.grizzly
Basic class for all ContextTasks, which are dealing with SelectionKeys
SelectionKeyContextTask() - Constructor for class com.sun.grizzly.SelectionKeyContextTask
 
selectionKeyHandler - Variable in class com.sun.grizzly.Controller
The SelectionKey Handler used by this instance.
SelectionKeyHandler - Interface in com.sun.grizzly
A SelectionKeyHandler is used to handle the life cycle of a SelectionKey.
selectionKeyHandler - Variable in class com.sun.grizzly.TCPSelectorHandler
The SelectionKeyHandler associated with this SelectorHandler.
SelectionKeyOP - Class in com.sun.grizzly.util
 
SelectionKeyOP.ConnectSelectionKeyOP - Class in com.sun.grizzly.util
 
SelectionKeyOP.ConnectSelectionKeyOP() - Constructor for class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
selectNowAndReturnSelector(Selector) - Static method in class com.sun.grizzly.util.SelectorFactory
Executes Selector.selectNow() and returns the Selector to the cache
selector - Variable in class com.sun.grizzly.TCPSelectorHandler
The single Selector.
SelectorFactory - Class in com.sun.grizzly.util
Factory used to dispatch/share Selector.
SelectorFactory() - Constructor for class com.sun.grizzly.util.SelectorFactory
 
selectorHandler - Variable in class com.sun.grizzly.async.AbstractAsyncQueueReader
 
selectorHandler - Variable in class com.sun.grizzly.async.AbstractAsyncQueueWriter
 
selectorHandler - Variable in class com.sun.grizzly.BaseSelectionKeyHandler
Associated SelectorHandler
SelectorHandler - Interface in com.sun.grizzly
A SelectorHandler handles all java.nio.channels.Selector operations.
selectorHandler - Variable in class com.sun.grizzly.SSLConnectorHandler
The underlying SSLSelectorHandler used to mange SelectionKeys.
selectorHandler - Variable in class com.sun.grizzly.TCPConnectorHandler
The underlying TCPSelectorHandler used to mange SelectionKeys.
selectorHandler - Variable in class com.sun.grizzly.UDPConnectorHandler
The underlying UDPSelectorHandler used to mange SelectionKeys.
SelectorHandlerRunner - Class in com.sun.grizzly
Class is responsible for processing certain (single) SelectorHandler
SelectorHandlerRunner(Controller, SelectorHandler) - Constructor for class com.sun.grizzly.SelectorHandlerRunner
 
selectorHandlers - Variable in class com.sun.grizzly.Controller
The set of SelectorHandlers used by this instance.
selectTimeout - Variable in class com.sun.grizzly.TCPSelectorHandler
The Selector time out.
send(ByteBuffer, SocketAddress) - Method in class com.sun.grizzly.UDPConnectorHandler
Receive bytes.
serverSocket - Variable in class com.sun.grizzly.TCPSelectorHandler
The ServerSocket instance.
serverSocketChannel - Variable in class com.sun.grizzly.TCPSelectorHandler
The ServerSocketChannel.
serverTimeout - Variable in class com.sun.grizzly.TCPSelectorHandler
The server socket time out
set(ByteBuffer, AsyncReadCallbackHandler, AsyncReadCondition, AsyncQueueDataProcessor, Future<AsyncQueueReadUnit>) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
set(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, SocketAddress, ByteBufferCloner, Future) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
set(E, StateHolder.EventListener) - Method in class com.sun.grizzly.util.StateHolder.ConditionListener
 
set(Object) - Method in class com.sun.grizzly.util.StateHolder.EventListener
 
setAsyncQueueReader(AsyncQueueReader) - Method in class com.sun.grizzly.async.AsyncQueueReaderContextTask
 
setAsyncQueueReader(AsyncQueueReader) - Method in class com.sun.grizzly.NIOContext
Set the
setAsyncQueueWriter(AsyncQueueWriter) - Method in class com.sun.grizzly.async.AsyncQueueWriterContextTask
 
setAsyncQueueWriter(AsyncQueueWriter) - Method in class com.sun.grizzly.NIOContext
Set the
setAttachment(A) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setAttachment(E) - Method in class com.sun.grizzly.util.SelectionKeyAttachmentWrapper
 
setAttribute(String, Object) - Method in class com.sun.grizzly.Controller
Set a key/value object.
setAttribute(String, Object) - Method in class com.sun.grizzly.NIOContext
Set a key/value object.
setAttribute(String, Object) - Method in class com.sun.grizzly.TCPSelectorHandler
Set a key/value object.
setAttribute(String, Object) - Method in interface com.sun.grizzly.util.AttributeHolder
Set a name/value object.
setAttribute(String, Object) - Method in class com.sun.grizzly.util.ThreadAttachment
 
setAttributes(Map<String, Object>) - Method in interface com.sun.grizzly.Context
Set a Map of attribute name/value pairs.
setAttributes(Map<String, Object>) - Method in class com.sun.grizzly.Controller
Set a Map of attribute name/value pairs.
setAttributes(Map<String, Object>) - Method in class com.sun.grizzly.NIOContext
Set a Map of attribute name/value pairs.
setAttributes(Map<String, Object>) - Method in class com.sun.grizzly.TCPSelectorHandler
Set a Map of attribute name/value pairs.
setAttributes(Map<String, Object>) - Method in interface com.sun.grizzly.util.AttributeHolder
Set a Map of attribute name/value pairs.
setAttributes(Map<String, Object>) - Method in class com.sun.grizzly.util.ThreadAttachment
 
setByteBuffer(ByteBuffer) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
setByteBuffer(ByteBuffer) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setByteBuffer(ByteBuffer) - Method in class com.sun.grizzly.util.InputReader
Set the wrapped ByteBuffer
setByteBuffer(ByteBuffer) - Method in class com.sun.grizzly.util.ThreadAttachment
Set the ByteBuffer shared this thread
setByteBuffer(ByteBuffer) - Method in class com.sun.grizzly.util.WorkerThread
Set the ByteBuffer shared this thread
setByteBufferCloner(ByteBufferCloner) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setByteBufferType(ByteBufferFactory.ByteBufferType) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
setByteBufferType(ByteBufferFactory.ByteBufferType) - Method in class com.sun.grizzly.util.WorkerThreadImpl
Set the ByteBufferType to use when creating the ByteBuffer associated with this object.
setCallbackHandler(AsyncReadCallbackHandler) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
setCallbackHandler(AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setCallBackHandler(CallbackHandler) - Method in class com.sun.grizzly.CallbackHandlerContextTask
 
setCallbackHandler(CallbackHandler) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
setCallbackHandler(P) - Method in interface com.sun.grizzly.ConnectorHandler
Sets ConnectorHandler's callback handler instance, which is used to process occuring events
setCallbackHandler(SSLCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Set the CallbackHandler.
setCallbackHandler(CallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Set the CallbackHandler.
setCallbackHandler(CallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Set the CallbackHandler.
setCallbackHandler(CallbackHandler) - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
setChannel(SelectableChannel) - Method in class com.sun.grizzly.util.SelectionKeyOP
 
setChannel(E) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Set the Channel used by this algorithm
setChannelType(InputReader.ChannelType) - Method in class com.sun.grizzly.util.InputReader
Set the Channel type, which is ocketChannel or DatagramChannel.
setClientMode(boolean) - Method in class com.sun.grizzly.filter.SSLReadFilter
Configures the engine to use client (or server) mode when handshaking.
setClientMode(boolean) - Method in class com.sun.grizzly.SSLConfig
 
setCloned(boolean) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setCondition(AsyncReadCondition) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
setConnectionCloseHandler(ConnectionCloseHandler) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Set the the ConnectionClosedHandler
setConnectionTimeout(int) - Method in class com.sun.grizzly.TCPConnectorHandler
Set TCP channel connection timeout in milliseconds
setConnectorHandlerPool(ConnectorHandlerPool) - Method in class com.sun.grizzly.Controller
Set the ConnectorHandlerPool used.
setContext(Context) - Method in class com.sun.grizzly.ContextTask
 
setContinuousExecution(boolean) - Method in class com.sun.grizzly.DefaultProtocolChain
Set to true if the current ExecutorService can re-execute its ProtocolFilter(s) after a successful execution.
setContinuousExecution(boolean) - Method in class com.sun.grizzly.filter.ReadFilter
Set to true if the current ExecutorService can re-execute its ProtocolFilter(s) after a successful execution.
setContinuousExecution(boolean) - Method in interface com.sun.grizzly.ReinvokeAware
Set to true if the current ExecutorService can re-execute its ProtocolFilter(s) after a successful execution.
setController(Controller) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
setController(Controller) - Method in interface com.sun.grizzly.ConnectorHandler
Set the Controller associated with this instance.
setController(Controller) - Method in class com.sun.grizzly.NIOContext
Set the current Controller.
setController(Controller) - Method in class com.sun.grizzly.SSLConnectorHandler
Set the Controller to use with this instance.
setController(Controller) - Method in class com.sun.grizzly.TCPConnectorHandler
Set the Controller to use with this instance.
setController(Controller) - Method in class com.sun.grizzly.UDPConnectorHandler
Set the Controller to use with this instance.
setCorePoolSize(int) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Sets the core number of threads.
setCurrentOpType(Context.OpType) - Method in class com.sun.grizzly.NIOContext
Set the current OpType value.
setDefaultReadTimeout(int) - Static method in class com.sun.grizzly.util.InputReader
Set the default Selector.select() time out.
setDefaultWriteTimeout(int) - Static method in class com.sun.grizzly.util.OutputWriter
 
setDelegateSSLTasks(boolean) - Method in class com.sun.grizzly.SSLConnectorHandler
 
setDelegateToProtocolChain(boolean) - Method in class com.sun.grizzly.DefaultCallbackHandler
Set to true> to enable delagation of the read and write operations to a ProtocolChain true> to enable delagation of the read and write operations to a ProtocolChain
setDstAddress(SocketAddress) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setEnabledCipherSuites(String[]) - Method in class com.sun.grizzly.filter.SSLReadFilter
Sets the list of cipher suites to be enabled when SSLEngine is initialized.
setEnabledProtocols(String[]) - Method in class com.sun.grizzly.filter.SSLReadFilter
Sets the list of protocols to be enabled when SSLEngine is initialized.
setException(Throwable) - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
setExpireTime(long) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setForeignKey(SelectionKey) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
setFuture(Future<AsyncQueueReadUnit>) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
setFuture(Future<AsyncQueueWriteUnit>) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
setHandleReadWriteConcurrently(boolean) - Method in class com.sun.grizzly.Controller
true if OP_ERAD and OP_WRITE can be handled concurrently.
setInet(InetAddress) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setInitialByteBufferSize(int) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
setInputBB(ByteBuffer) - Method in class com.sun.grizzly.util.ThreadAttachment
Set the encrypted ByteBuffer used to handle request.
setInputBB(ByteBuffer) - Method in class com.sun.grizzly.util.WorkerThread
Set the encrypted ByteBuffer used to handle request.
setIOEvent(IOEvent<Context>) - Method in interface com.sun.grizzly.Context
Set an optional CallbackHandler.
setIOEvent(IOEvent<Context>) - Method in class com.sun.grizzly.NIOContext
Set an optional CallbackHandler.
setKeepAliveTime(long, TimeUnit) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Sets the time limit for which threads may remain idle before being terminated.
setKey(SelectionKey) - Method in class com.sun.grizzly.suspendable.Suspendable
Set the underlying SelectionKey.
setKey(SelectionKey) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
setKeyRegistrationState(Context.KeyRegistrationState) - Method in interface com.sun.grizzly.Context
Set the SelectionKey's next registration state
setKeyRegistrationState(Context.KeyRegistrationState) - Method in class com.sun.grizzly.NIOContext
Set the SelectionKey's next registration state
setKeyStoreAlgorithm(String) - Method in class com.sun.grizzly.SSLConfig
 
setKeyStoreFile(String) - Method in class com.sun.grizzly.SSLConfig
 
setKeyStorePass(String) - Method in class com.sun.grizzly.SSLConfig
 
setKeyStoreType(String) - Method in class com.sun.grizzly.SSLConfig
 
setLinger(int) - Method in class com.sun.grizzly.TCPConnectorHandler
 
setLinger(int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setLinger(int) - Method in class com.sun.grizzly.UDPSelectorHandler
 
setLocalAddress(SocketAddress) - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
setLockEnabled(boolean) - Method in class com.sun.grizzly.util.StateHolder
Setss current locking mode
setLogger(Logger) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
 
setLogger(Logger) - Static method in class com.sun.grizzly.Controller
Set the Logger single instance to use.
setLogger(Logger) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setMaximumPoolSize(int) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
Sets the maximum allowed number of threads.
setMaxQueuedTasksCount(int) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
setMaxQueuedTasksCount(int) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
 
setMaxSelectors(int) - Static method in class com.sun.grizzly.util.SelectorFactory
Set max selector pool size.
setMode(int) - Method in class com.sun.grizzly.util.ThreadAttachment
 
setName(String) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
setName(String) - Method in interface com.sun.grizzly.util.ExtendedThreadPool
 
setNeedClientAuth(boolean) - Method in class com.sun.grizzly.filter.SSLReadFilter
Configures the engine to require client authentication.
setNeedClientAuth(boolean) - Method in class com.sun.grizzly.SSLConfig
 
setOp(int) - Method in class com.sun.grizzly.util.SelectionKeyOP
 
setOutputBB(ByteBuffer) - Method in class com.sun.grizzly.util.ThreadAttachment
Set the encrypted ByteBuffer used to handle response.
setOutputBB(ByteBuffer) - Method in class com.sun.grizzly.util.WorkerThread
Set the encrypted ByteBuffer used to handle response.
setPort(int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setPort(int) - Method in interface com.sun.grizzly.util.StreamAlgorithm
Deprecated. Set the port this algorithm is used.
setPriority(int) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
setProtocol(Controller.Protocol) - Method in class com.sun.grizzly.NIOContext
 
setProtocolChain(ProtocolChain) - Method in interface com.sun.grizzly.Context
Set the ProtocolChain used by this Context.
setProtocolChain(ProtocolChain) - Method in class com.sun.grizzly.NIOContext
Set the ProtocolChain used by this Context.
setProtocolChain(ProtocolChain) - Method in class com.sun.grizzly.SingleProtocolChainInstanceHandler
Set the stateless ProtocolChain instance, which will be always returned via StatelessProtocolChainInstanceHandler#poll().
setProtocolChainInstanceHandler(ProtocolChainInstanceHandler) - Method in class com.sun.grizzly.Controller
Set the ProtocolChainInstanceHandler to use for creating instance of ProtocolChain.
setProtocolChainInstanceHandler(ProtocolChainInstanceHandler) - Method in interface com.sun.grizzly.SelectorHandler
Set the ProtocolChainInstanceHandler to use for creating instance of ProtocolChain.
setProtocolChainInstanceHandler(ProtocolChainInstanceHandler) - Method in class com.sun.grizzly.TCPSelectorHandler
Set the ProtocolChainInstanceHandler to use for creating instance of ProtocolChain.
setProtocolFilter(int, ProtocolFilter) - Method in class com.sun.grizzly.DefaultProtocolChain
Insert a ProtocolFilter at position pos.
setReadAttempts(int) - Method in class com.sun.grizzly.filter.ReadFilter
Set the number of attempts the ReadFilter will try to read a data from a channel.
setReadPostProcessor(AsyncQueueDataProcessor) - Method in class com.sun.grizzly.async.AsyncQueueReadUnit
 
setReadThreadsCount(int) - Method in class com.sun.grizzly.Controller
Set the number of Reader threads count.
setReadTimeout(int) - Method in class com.sun.grizzly.util.InputReader
Set the timeout between two consecutives Selector.select() when a temporary Selector is used.
setReadTimeout(int) - Static method in class com.sun.grizzly.util.SSLUtils
 
setRegistrationTime(long) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
setRemoteAddress(SocketAddress) - Method in class com.sun.grizzly.util.SelectionKeyOP.ConnectSelectionKeyOP
 
setResult(E) - Method in class com.sun.grizzly.async.AsyncQueueFuture
 
setReuseAddress(boolean) - Method in class com.sun.grizzly.TCPConnectorHandler
 
setReuseAddress(boolean) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setRole(Role) - Method in class com.sun.grizzly.TCPSelectorHandler
Sets this SelectorHandler current role.
setSecure(boolean) - Method in class com.sun.grizzly.util.InputReader
Set this stream secure.
setSecurityProtocol(String) - Method in class com.sun.grizzly.SSLConfig
 
setSelectionKey(SelectionKey) - Method in class com.sun.grizzly.NIOContext
Set the connection SelectionKey.
setSelectionKey(SelectionKey) - Method in class com.sun.grizzly.util.InputReader
Set the SelectionKey used to reads bytes.
setSelectionKey(SelectionKey) - Method in class com.sun.grizzly.util.SelectionKeyOP
 
setSelectionKeyHandler(SelectionKeyHandler) - Method in class com.sun.grizzly.Controller
Deprecated. Set the SelectionKeyHandler to use for managing the life cycle of SelectionKey. Method is deprecated. Use SelectorHandler.setSelectionKeyHandler() instead
setSelectionKeyHandler(SelectionKeyHandler) - Method in interface com.sun.grizzly.SelectorHandler
Set SelectionKeyHandler associated with this SelectorHandler.
setSelectionKeyHandler(SelectionKeyHandler) - Method in class com.sun.grizzly.TCPSelectorHandler
Set SelectionKeyHandler associated with this SelectorHandler.
setSelector(Selector) - Method in interface com.sun.grizzly.SelectorHandler
Sets the underlying Selector
setSelector(Selector) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.BaseSelectionKeyHandler
Set associated SelectorHandler
setSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.Controller
Set the first SelectorHandler
setSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.NIOContext
Set the current SelectorHandler this instance is executing.
setSelectorHandler(SelectorHandler) - Method in interface com.sun.grizzly.SelectionKeyHandler
Set associated SelectorHandler
setSelectorHandler(SelectorHandler) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setSelectTimeout(long) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setServerTimeout(int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setSkipRead(boolean) - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Method set if this Filter should perform channel read operation on execute, or should assumes the data was read by previous Filters in a chain.
setSocketTimeout(int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setSocketTimeout(int) - Method in class com.sun.grizzly.UDPSelectorHandler
 
setSsBackLog(int) - Method in class com.sun.grizzly.TCPSelectorHandler
 
setSsBackLog(int) - Method in class com.sun.grizzly.UDPSelectorHandler
 
setSSLConfig(SSLConfig) - Method in class com.sun.grizzly.filter.ParserProtocolFilter
Configures this Filter to be used with SSL.
setSSLContext(SSLContext) - Method in class com.sun.grizzly.filter.SSLReadFilter
Set the SSLContext required to support SSL over NIO.
setSSLContext(SSLContext) - Method in class com.sun.grizzly.SSLConnectorHandler
Set SSLContext.
setSSLEngine(SSLEngine) - Method in class com.sun.grizzly.SSLConnectorHandler
SetSSLEngine
setSSLEngine(SSLEngine) - Method in class com.sun.grizzly.util.ThreadAttachment
Get theSSLEngine.
setSSLEngine(SSLEngine) - Method in class com.sun.grizzly.util.WorkerThread
Get theSSLEngine.
setState(E) - Method in class com.sun.grizzly.util.StateHolder
Sets current state Current StateHolder locking mode will be used
setState(E, boolean) - Method in class com.sun.grizzly.util.StateHolder
Sets current state
setSuspendable(Suspendable) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setSuspendableFilter(SuspendableFilter) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setSuspendableHandler(SuspendableFilter.SuspendableHandlerWrapper) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
setSuspendableHandler(SuspendableHandler<A>) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setSuspendWhen(SuspendableFilter.Suspend) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
setTcpNoDelay(boolean) - Method in class com.sun.grizzly.TCPConnectorHandler
Enable (true) or disable (false) the underlying Socket's tcpNoDelay.
setTcpNoDelay(boolean) - Method in class com.sun.grizzly.TCPSelectorHandler
Enable (true) or disable (false) the underlying Socket's tcpNoDelay.
setTcpNoDelay(boolean) - Method in class com.sun.grizzly.UDPSelectorHandler
 
setThreadAttachment(ThreadAttachment) - Method in class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
setThreadId(String) - Method in class com.sun.grizzly.util.ThreadAttachment
Set the Thread's name on which this instance is binded.
setThreadPool(ExecutorService) - Method in interface com.sun.grizzly.Context
Set the ExecutorService that will execute this instance.
setThreadPool(ExecutorService) - Method in class com.sun.grizzly.Controller
Set the ExecutorService (Thread Pool).
setThreadPool(ExecutorService) - Method in class com.sun.grizzly.NIOContext
Set the ExecutorService that will execute this instance.
setThreadPool(ExecutorService) - Method in interface com.sun.grizzly.SelectorHandler
Set the ExecutorService used to execute this SelectorHandler's SelectionKey ops
setThreadPool(ExecutorService) - Method in class com.sun.grizzly.TCPSelectorHandler
Set the ExecutorService used to execute this SelectorHandler's SelectionKey ops
setTimeout(long) - Method in class com.sun.grizzly.DefaultSelectionKeyHandler
 
setTimeout(Long) - Method in class com.sun.grizzly.util.SelectionKeyAttachment
 
setTrustStoreAlgorithm(String) - Method in class com.sun.grizzly.SSLConfig
 
setTrustStoreFile(String) - Method in class com.sun.grizzly.SSLConfig
 
setTrustStorePass(String) - Method in class com.sun.grizzly.SSLConfig
 
setTrustStoreType(String) - Method in class com.sun.grizzly.SSLConfig
 
setUnderlyingChannel(SocketChannel) - Method in class com.sun.grizzly.SSLConnectorHandler
Set the SocketChannel.
setUnderlyingChannel(SocketChannel) - Method in class com.sun.grizzly.TCPConnectorHandler
Set the SocketChannel.
setWantClientAuth(boolean) - Method in class com.sun.grizzly.filter.SSLReadFilter
Configures the engine to request client authentication.
setWantClientAuth(boolean) - Method in class com.sun.grizzly.SSLConfig
 
setWritePreProcessor(AsyncQueueDataProcessor) - Method in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
shutdown() - Method in interface com.sun.grizzly.SelectorHandler
Shutdown this instance.
shutdown() - Method in class com.sun.grizzly.TCPSelectorHandler
Shuntdown this instance by closing its Selector and associated channels.
shutdown() - Method in class com.sun.grizzly.UDPSelectorHandler
Shuntdown this instance by closing its Selector and associated channels.
SingleProtocolChainInstanceHandler - Class in com.sun.grizzly
Implementation of an ProtocolChainInstanceHandler.
SingleProtocolChainInstanceHandler() - Constructor for class com.sun.grizzly.SingleProtocolChainInstanceHandler
 
SingleProtocolChainInstanceHandler(ProtocolChain) - Constructor for class com.sun.grizzly.SingleProtocolChainInstanceHandler
 
size(K) - Method in class com.sun.grizzly.async.AsyncQueue
Get the size of K key related queue.
size() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueBlockingImpl
 
size() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueImpl
 
size() - Method in class com.sun.grizzly.connectioncache.impl.concurrent.ConcurrentQueueNonBlockingImpl
 
size() - Method in interface com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueue
Return the number of elements in the queue.
socketTimeout - Variable in class com.sun.grizzly.TCPSelectorHandler
The socket time out
ssBackLog - Variable in class com.sun.grizzly.TCPSelectorHandler
Server socket backlog.
SSL_ARTIFACTS - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
SSL_ENGINE - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
SSLCallbackHandler<E> - Interface in com.sun.grizzly
This class extends the CallbackHandler functionalities by exposing the onHandshake method.
SSLConfig - Class in com.sun.grizzly
SSL configuration
SSLConfig() - Constructor for class com.sun.grizzly.SSLConfig
 
SSLConfig(boolean) - Constructor for class com.sun.grizzly.SSLConfig
 
SSLConnectorHandler - Class in com.sun.grizzly
Non blocking SSL Connector Handler.
SSLConnectorHandler() - Constructor for class com.sun.grizzly.SSLConnectorHandler
 
SSLConnectorHandler(SSLConfig) - Constructor for class com.sun.grizzly.SSLConnectorHandler
 
SSLConnectorHandler(SSLContext) - Constructor for class com.sun.grizzly.SSLConnectorHandler
 
sslContext - Variable in class com.sun.grizzly.filter.SSLReadFilter
The SSLContext associated with the SSL implementation we are running on.
SSLEchoAsyncWriteQueueFilter - Class in com.sun.grizzly.filter
SSL echo filter, which uses AsyncQueueWriter
SSLEchoAsyncWriteQueueFilter() - Constructor for class com.sun.grizzly.filter.SSLEchoAsyncWriteQueueFilter
 
SSLEchoFilter - Class in com.sun.grizzly.filter
Simple echo filter
SSLEchoFilter() - Constructor for class com.sun.grizzly.filter.SSLEchoFilter
 
sslEngine - Variable in class com.sun.grizzly.util.WorkerThread
TheSSLEngine used to manage the SSL over NIO request.
SSLOutputWriter - Class in com.sun.grizzly.util
SSL over NIO utility to encrypt ByteBuffer and flush them.
SSLOutputWriter() - Constructor for class com.sun.grizzly.util.SSLOutputWriter
 
SSLReadFilter - Class in com.sun.grizzly.filter
Simple ProtocolFilter implementation which execute an SSL handshake and decrypt the bytes, the pass the control to the next filter.
SSLReadFilter() - Constructor for class com.sun.grizzly.filter.SSLReadFilter
 
SSLSelectorHandler - Class in com.sun.grizzly
A SelectorHandler handles all java.nio.channels.Selector operations.
SSLSelectorHandler() - Constructor for class com.sun.grizzly.SSLSelectorHandler
 
SSLSelectorHandler(boolean) - Constructor for class com.sun.grizzly.SSLSelectorHandler
SSLSelectorHandler constructor
SSLUtils - Class in com.sun.grizzly.util
SSL over NIO utility class.
SSLUtils() - Constructor for class com.sun.grizzly.util.SSLUtils
 
start() - Method in class com.sun.grizzly.Controller
Start the Controller.
start() - Method in interface com.sun.grizzly.Lifecycle
Start the Lifecycle.
start() - Method in class com.sun.grizzly.ReadController
Start the Controller.
start() - Method in class com.sun.grizzly.suspendable.SuspendableMonitor
 
start() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
startBuffer(ByteBuffer) - Method in interface com.sun.grizzly.ProtocolParser
Set the buffer to be parsed.
State - Enum in com.sun.grizzly.util
State enum STOPPED - Process is stopped, not running state STARTED - Process is started, running state PAUSED - Process is paused, not processing tasks
state - Variable in class com.sun.grizzly.util.StateHolder.ConditionListener
 
stateHolder - Variable in class com.sun.grizzly.Controller
Current Controller state
stateHolder - Variable in class com.sun.grizzly.TCPSelectorHandler
This SelectorHandler StateHolder, which is shared among SelectorHandler and its clones
StateHolder<E> - Class in com.sun.grizzly.util
Class, which holds the state.
StateHolder() - Constructor for class com.sun.grizzly.util.StateHolder
Constructs StateHolder.
StateHolder(boolean) - Constructor for class com.sun.grizzly.util.StateHolder
Constructs StateHolder.
StateHolder.ConditionListener<E> - Class in com.sun.grizzly.util
Common ConditionListener class, which could be used with StateHolder, to register custom conditions.
StateHolder.ConditionListener() - Constructor for class com.sun.grizzly.util.StateHolder.ConditionListener
 
StateHolder.EqualConditionListener<E> - Class in com.sun.grizzly.util
Equal ConditionListener implementation
StateHolder.EqualConditionListener() - Constructor for class com.sun.grizzly.util.StateHolder.EqualConditionListener
 
StateHolder.EventListener - Class in com.sun.grizzly.util
EventListener class, which is a part of EventConditionListener, and implements notificatation logic, when condition becomes true.
StateHolder.EventListener() - Constructor for class com.sun.grizzly.util.StateHolder.EventListener
 
StateHolder.NotEqualConditionListener<E> - Class in com.sun.grizzly.util
Not equal ConditionListener implementation
StateHolder.NotEqualConditionListener() - Constructor for class com.sun.grizzly.util.StateHolder.NotEqualConditionListener
 
stateListeners - Variable in class com.sun.grizzly.Controller
Collection of Controller state listeners, which will are notified on Controller state change.
stop() - Method in class com.sun.grizzly.Controller
Stop the Controller by canceling all the registered keys.
stop(boolean) - Method in class com.sun.grizzly.Controller
Stop the Controller by canceling all the registered keys.
stop() - Method in interface com.sun.grizzly.Lifecycle
Stops the Lifecycle.
stop() - Method in class com.sun.grizzly.ReadController
Stop the Controller by canceling all the registered keys.
stop() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
stoppedSelectorHandlerCounter - Variable in class com.sun.grizzly.Controller
Internal countdown counter of SelectorHandlers, which stopped
STORE_ALL - Static variable in class com.sun.grizzly.util.ThreadAttachment.Mode
 
StreamAlgorithm<E> - Interface in com.sun.grizzly.util
Deprecated. Use the ProtocolParser instead.
SUCCESSFUL_READ - Static variable in interface com.sun.grizzly.ProtocolFilter
 
supportsProtocol(Controller.Protocol) - Method in interface com.sun.grizzly.ComplexSelectorHandler
Checks if protocol is supported by RoundRobinSelectorHandler
supportsProtocol(Controller.Protocol) - Method in class com.sun.grizzly.RoundRobinSelectorHandler
Checks if protocol is supported by RoundRobinSelectorHandler
SupportStateHolder<E> - Interface in com.sun.grizzly.util
Interface implementors support StateHolder for state control
suspend() - Method in interface com.sun.grizzly.Context
Suspend the execution of this Context.
suspend() - Method in class com.sun.grizzly.NIOContext
Suspend the execution of this Context.
suspend(String) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Suspend a connection based on a String.
suspend(String, long, T, SuspendableHandler<? extends T>) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Suspend a connection based on a String.
suspend(String, long, T, SuspendableHandler<? extends T>, SuspendableFilter.Suspend) - Method in class com.sun.grizzly.suspendable.SuspendableFilter
Suspend a connection based on a String.
suspend(SuspendableFilter.KeyHandler) - Method in class com.sun.grizzly.suspendable.SuspendableMonitor
Suspend the ReadableChannel represented by this SuspendableFilter.KeyHandler by registering it on secondary Selector.
Suspendable - Class in com.sun.grizzly.suspendable
An Object representing the result of an suspendable operation like SuspendableFilter@#suspend An instance of that class can be used to resume or cancel a suspended connection.
Suspendable(SuspendableFilter) - Constructor for class com.sun.grizzly.suspendable.Suspendable
 
SuspendableFilter<T> - Class in com.sun.grizzly.suspendable
Suspend the processing of the request and associated ProtocolChain When a connection is suspended, the framework will not continue the execution of the ProtocolChain and its associated ProtocolFilter.
SuspendableFilter() - Constructor for class com.sun.grizzly.suspendable.SuspendableFilter
 
SuspendableFilter(int) - Constructor for class com.sun.grizzly.suspendable.SuspendableFilter
Create a new SuspendableFilter, and resume its associated DefaultProtocolChain from position SuspendableFilter.nextFilterPosition
SuspendableFilter.KeyHandler - Class in com.sun.grizzly.suspendable
Struc to keep state of the current suspended Connection.
SuspendableFilter.KeyHandler() - Constructor for class com.sun.grizzly.suspendable.SuspendableFilter.KeyHandler
 
SuspendableFilter.Suspend - Enum in com.sun.grizzly.suspendable
Suspend the connection BEFORE of AFTER
SuspendableFilter.SuspendableHandlerWrapper<A> - Class in com.sun.grizzly.suspendable
Wrapper class around a SuspendableHandler with add some connection state.
SuspendableFilter.SuspendableHandlerWrapper(SuspendableHandler<A>, A, long, Suspendable, SuspendableFilter.Suspend) - Constructor for class com.sun.grizzly.suspendable.SuspendableFilter.SuspendableHandlerWrapper
 
SuspendableHandler<A> - Interface in com.sun.grizzly.suspendable
A handler for consuming the result of an suspendable operation.
SuspendableMonitor - Class in com.sun.grizzly.suspendable
A secondary Selector used to keep the state of a suspended connection (SelectionKey).
SuspendableMonitor() - Constructor for class com.sun.grizzly.suspendable.SuspendableMonitor
Start a new Thread with a Selector running.
suspendedKeys - Variable in class com.sun.grizzly.suspendable.SuspendableFilter
The current list of suspended SelectionKey.

T

TCPAsyncQueueReader - Class in com.sun.grizzly.async
 
TCPAsyncQueueReader(SelectorHandler) - Constructor for class com.sun.grizzly.async.TCPAsyncQueueReader
 
TCPAsyncQueueWriter - Class in com.sun.grizzly.async
TCP implementation of AsyncQueueWriter
TCPAsyncQueueWriter(SelectorHandler) - Constructor for class com.sun.grizzly.async.TCPAsyncQueueWriter
 
TCPConnectorHandler - Class in com.sun.grizzly
Non blocking TCP Connector Handler.
TCPConnectorHandler() - Constructor for class com.sun.grizzly.TCPConnectorHandler
 
tcpNoDelay - Variable in class com.sun.grizzly.TCPConnectorHandler
The socket tcpDelay.
tcpNoDelay - Variable in class com.sun.grizzly.TCPSelectorHandler
The socket tcpDelay.
TCPSelectorHandler - Class in com.sun.grizzly
A SelectorHandler handles all java.nio.channels.Selector operations.
TCPSelectorHandler() - Constructor for class com.sun.grizzly.TCPSelectorHandler
 
TCPSelectorHandler(boolean) - Constructor for class com.sun.grizzly.TCPSelectorHandler
Create a TCPSelectorHandler only used with ConnectorHandler.
TCPSelectorHandler(Role) - Constructor for class com.sun.grizzly.TCPSelectorHandler
Create a TCPSelectorHandler only used with ConnectorHandler.
thisClassName() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
thisClassName() - Method in class com.sun.grizzly.connectioncache.impl.transport.InboundConnectionCacheBlockingImpl
 
thisClassName() - Method in class com.sun.grizzly.connectioncache.impl.transport.OutboundConnectionCacheBlockingImpl
 
ThreadAttachment - Class in com.sun.grizzly.util
This object represent the state of a WorkerThread.
ThreadAttachment() - Constructor for class com.sun.grizzly.util.ThreadAttachment
 
ThreadAttachment.Mode - Class in com.sun.grizzly.util
 
ThreadAttachment.Mode() - Constructor for class com.sun.grizzly.util.ThreadAttachment.Mode
 
threadGroup - Static variable in class com.sun.grizzly.util.WorkerThreadImpl
The ThreadGroup used.
threadPool - Variable in class com.sun.grizzly.Controller
Default Thread Pool (called ExecutorService).If not set, and instance of the DefaultThreadPool will be created.
threadPool - Variable in class com.sun.grizzly.TCPSelectorHandler
The ExecutorService used by this instance.
threadPool - Variable in class com.sun.grizzly.util.WorkerThreadImpl
The DefaultThreadPool on which this thread synchronize.
THROWABLE - Static variable in interface com.sun.grizzly.Context
Constant 'throwable' String
timeout - Variable in class com.sun.grizzly.DefaultSelectionKeyHandler
 
timeout - Static variable in class com.sun.grizzly.util.SelectorFactory
The timeout before we exit.
tmpResult - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
toString() - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
toString() - Method in class com.sun.grizzly.connectioncache.impl.transport.ConnectionCacheBase
 
toString() - Method in class com.sun.grizzly.util.DefaultThreadPool
 
toString() - Method in class com.sun.grizzly.util.ThreadAttachment
 
totalElementsCount - Variable in class com.sun.grizzly.async.AsyncQueue.AsyncQueueEntry
 
TRUST_STORE_FILE - Static variable in class com.sun.grizzly.SSLConfig
 
TRUST_STORE_PASSWORD - Static variable in class com.sun.grizzly.SSLConfig
 
TRUST_STORE_TYPE - Static variable in class com.sun.grizzly.SSLConfig
 

U

UDP_SOCKETADDRESS - Static variable in class com.sun.grizzly.filter.ReadFilter
 
UDP_SOCKETADDRESS - Static variable in class com.sun.grizzly.filter.UDPReadFilter
Deprecated.  
UDP_SOCKETADDRESS - Static variable in class com.sun.grizzly.filter.UDPWriteFilter
 
UDPAsyncQueueReader - Class in com.sun.grizzly.async
 
UDPAsyncQueueReader(SelectorHandler) - Constructor for class com.sun.grizzly.async.UDPAsyncQueueReader
 
UDPAsyncQueueWriter - Class in com.sun.grizzly.async
UDP implementation of AsyncQueueWriter
UDPAsyncQueueWriter(SelectorHandler) - Constructor for class com.sun.grizzly.async.UDPAsyncQueueWriter
 
UDPConnectorHandler - Class in com.sun.grizzly
Client side interface used to implement non blocking client operation.
UDPConnectorHandler() - Constructor for class com.sun.grizzly.UDPConnectorHandler
 
UDPReadFilter - Class in com.sun.grizzly.filter
Deprecated. The ReadFilter can be used for both TCP and UDP.
UDPReadFilter() - Constructor for class com.sun.grizzly.filter.UDPReadFilter
Deprecated.  
UDPSelectorHandler - Class in com.sun.grizzly
A SelectorHandler handles all java.nio.channels.Selector operations.
UDPSelectorHandler() - Constructor for class com.sun.grizzly.UDPSelectorHandler
 
UDPSelectorHandler(boolean) - Constructor for class com.sun.grizzly.UDPSelectorHandler
 
UDPSelectorHandler(Role) - Constructor for class com.sun.grizzly.UDPSelectorHandler
 
UDPWriteFilter - Class in com.sun.grizzly.filter
Simple ProtocolFilter implementation which write the available bytes and delegate the processing to the next ProtocolFilter in the ProtocolChain.
UDPWriteFilter() - Constructor for class com.sun.grizzly.filter.UDPWriteFilter
 
uncaughtException(Thread, Throwable) - Method in class com.sun.grizzly.util.DefaultThreadPool
 
unwrap(ByteBuffer, ByteBuffer, SSLEngine) - Static method in class com.sun.grizzly.util.SSLUtils
Unwrap available encrypted bytes from inputBB to ByteBuffer using theSSLEngine
unwrapAll(ByteBuffer, ByteBuffer, SSLEngine) - Static method in class com.sun.grizzly.util.SSLUtils
Unwrap all encrypted bytes from inputBB to ByteBuffer using theSSLEngine
updateAttachment(int) - Method in class com.sun.grizzly.util.WorkerThread
Updates Thread associated attachment according to the passed mode.
updateAttachment(int) - Method in class com.sun.grizzly.util.WorkerThreadImpl
 
Utils - Class in com.sun.grizzly.util
Class contains set of useful operations commonly used in the framework
Utils() - Constructor for class com.sun.grizzly.util.Utils
 

V

value() - Method in interface com.sun.grizzly.connectioncache.spi.concurrent.ConcurrentQueue.Handle
Return the value that corresponds to this handle.
valueOf(String) - Static method in enum com.sun.grizzly.Context.AttributeScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.Context.KeyRegistrationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.Context.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.Controller.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.DefaultProtocolChain.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.ProtocolChainInstruction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.Role
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.suspendable.SuspendableFilter.Suspend
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.util.ByteBufferFactory.ByteBufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.util.InputReader.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.sun.grizzly.util.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.sun.grizzly.Context.AttributeScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.Context.KeyRegistrationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.Context.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.Controller.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.DefaultProtocolChain.Phase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.ProtocolChainInstruction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.Role
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.suspendable.SuspendableFilter.Suspend
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.util.ByteBufferFactory.ByteBufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.util.InputReader.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.sun.grizzly.util.State
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitUntilSeletorHandlersStop() - Method in class com.sun.grizzly.Controller
Method waits until all initialized SelectorHandlers will not get stopped
WorkerThread - Class in com.sun.grizzly.util
Simple interface to allow the addition of Thread attributes.
WorkerThread() - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(String) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(Runnable) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(Runnable, String) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(ThreadGroup, String) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(ThreadGroup, Runnable) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(ThreadGroup, Runnable, String) - Constructor for class com.sun.grizzly.util.WorkerThread
 
WorkerThread(ThreadGroup, Runnable, String, long) - Constructor for class com.sun.grizzly.util.WorkerThread
 
workerThreadCounter - Variable in class com.sun.grizzly.util.DefaultThreadPool
 
WorkerThreadFactory - Class in com.sun.grizzly.util
Simple utility class to create WorkerThread
WorkerThreadFactory() - Constructor for class com.sun.grizzly.util.WorkerThreadFactory
 
WorkerThreadImpl - Class in com.sun.grizzly.util
Simple worker thread used for processing HTTP requests.
WorkerThreadImpl(ThreadGroup, Runnable) - Constructor for class com.sun.grizzly.util.WorkerThreadImpl
Create a Thread that will synchronizes/block on DefaultThreadPool instance.
WorkerThreadImpl(ThreadGroup, Runnable, int) - Constructor for class com.sun.grizzly.util.WorkerThreadImpl
Create a Thread that will synchronizes/block on DefaultThreadPool instance.
WorkerThreadImpl(DefaultThreadPool, String) - Constructor for class com.sun.grizzly.util.WorkerThreadImpl
Create a Thread that will synchronizes/block on DefaultThreadPool instance.
WorkerThreadImpl(DefaultThreadPool, String, int) - Constructor for class com.sun.grizzly.util.WorkerThreadImpl
Create a Thread that will synchronizes/block on DefaultThreadPool instance.
WorkerThreadImpl(DefaultThreadPool, String, Runnable, int) - Constructor for class com.sun.grizzly.util.WorkerThreadImpl
Create a Thread that will synchronizes/block on DefaultThreadPool instance.
wrap(ByteBuffer, ByteBuffer, SSLEngine) - Static method in class com.sun.grizzly.util.SSLUtils
Encrypt bytes.
write(SelectionKey, ByteBuffer) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.async.AbstractAsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method writes ByteBuffer to the SelectableChannel First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SelectableChannel directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in interface com.sun.grizzly.async.AsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(SelectionKey, SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.async.TCPAsyncQueueWriter
Method sends ByteBuffer to the SocketAddress First, if SelectableChannel associated write queue is empty - it tries to write ByteBuffer to the given SocketAddress directly (without putting to the queue).
write(ByteBuffer, boolean) - Method in class com.sun.grizzly.connectioncache.client.CacheableConnectorHandler
 
write(ByteBuffer, boolean) - Method in interface com.sun.grizzly.ConnectorHandler
Writes bytes.
write(ByteBuffer, boolean) - Method in class com.sun.grizzly.SSLConnectorHandler
Writes bytes.
write(ByteBuffer, boolean) - Method in class com.sun.grizzly.TCPConnectorHandler
Writes bytes.
write(ByteBuffer, boolean) - Method in class com.sun.grizzly.UDPConnectorHandler
Writes bytes.
writePreProcessor - Variable in class com.sun.grizzly.async.AsyncQueueWriteUnit
 
writeToAsyncQueue(ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in interface com.sun.grizzly.async.AsyncQueueWritable
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer) - Method in class com.sun.grizzly.SSLConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.SSLConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.SSLConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer) - Method in class com.sun.grizzly.SSLConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.SSLConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.SSLConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.SSLConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer) - Method in class com.sun.grizzly.TCPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.TCPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.TCPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer) - Method in class com.sun.grizzly.TCPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.TCPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.TCPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.TCPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer) - Method in class com.sun.grizzly.UDPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.UDPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.UDPConnectorHandler
Method writes ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer) - Method in class com.sun.grizzly.UDPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler) - Method in class com.sun.grizzly.UDPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor) - Method in class com.sun.grizzly.UDPConnectorHandler
Method sends ByteBuffer using async write queue.
writeToAsyncQueue(SocketAddress, ByteBuffer, AsyncWriteCallbackHandler, AsyncQueueDataProcessor, ByteBufferCloner) - Method in class com.sun.grizzly.UDPConnectorHandler
Method sends ByteBuffer using async write queue.

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

Copyright © 2008 SUN Microsystems. All Rights Reserved.