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

O

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