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

A

A - Static variable in class org.glassfish.grizzly.http.server.Constants
'A'.
a - Static variable in class org.glassfish.grizzly.http.server.Constants
'a'.
A - Static variable in class org.glassfish.grizzly.http.util.Constants
'A'.
a - Static variable in class org.glassfish.grizzly.http.util.Constants
'a'.
AbstractBindingHandler - Class in org.glassfish.grizzly
 
AbstractBindingHandler(NIOTransport) - Constructor for class org.glassfish.grizzly.AbstractBindingHandler
 
AbstractBindingHandler.Builder<E extends AbstractBindingHandler.Builder> - Class in org.glassfish.grizzly
Builder
AbstractBindingHandler.Builder() - Constructor for class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
AbstractBufferArray<E> - Class in org.glassfish.grizzly.memory
 
AbstractBufferArray(Class<E>) - Constructor for class org.glassfish.grizzly.memory.AbstractBufferArray
 
AbstractCodecFilter<K,L> - Class in org.glassfish.grizzly.filterchain
 
AbstractCodecFilter(Transformer<K, L>, Transformer<L, K>) - Constructor for class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
AbstractFilterChain - Class in org.glassfish.grizzly.filterchain
AbstractFilterChain() - Constructor for class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
AbstractIOStrategy - Class in org.glassfish.grizzly.strategies
 
AbstractIOStrategy() - Constructor for class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
AbstractMemoryManager<E extends Buffer> - Class in org.glassfish.grizzly.memory
A MemoryManager abstraction to provide utilities that may be useful across different MemoryManager implementations.
AbstractMemoryManager() - Constructor for class org.glassfish.grizzly.memory.AbstractMemoryManager
Creates a new AbstractMemoryManager using a max buffer size of 65536.
AbstractMemoryManager(int) - Constructor for class org.glassfish.grizzly.memory.AbstractMemoryManager
Creates a new AbstractMemoryManager using the specified buffer size.
AbstractMemoryManager.TrimAware - Interface in org.glassfish.grizzly.memory
This is a marker interface indicating a particular Buffer implementation can be trimmed.
AbstractMultivaluedMap<K,V> - Class in org.glassfish.tyrus.core.uri.internal
Abstract skeleton implementation of a MultivaluedMap that is backed by a [key, multi-value] store represented as a Map<K, List<V>>.
AbstractMultivaluedMap() - Constructor for class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Initialize map and use HashMap as a backing store.
AbstractMultivaluedMap(Map<K, List<V>>) - Constructor for class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Initialize the backing store in the abstract parent multivalued map implementation.
AbstractNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio
The AsyncQueueReader implementation, based on the Java NIO
AbstractNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
AbstractNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio
The AsyncQueueWriter implementation, based on the Java NIO
AbstractNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
AbstractNIOConnectionDistributor - Class in org.glassfish.grizzly.nio
 
AbstractNIOConnectionDistributor(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
AbstractReader<L> - Class in org.glassfish.grizzly
Abstract class, which provides transitive dependencies for overloaded Reader methods.
AbstractReader() - Constructor for class org.glassfish.grizzly.AbstractReader
 
AbstractSocketConnectorHandler - Class in org.glassfish.grizzly
Abstract class simplifies the implementation of SocketConnectorHandler interface by pre-implementing some of its methods.
AbstractSocketConnectorHandler(Transport) - Constructor for class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
AbstractSocketConnectorHandler.Builder<E extends AbstractSocketConnectorHandler.Builder> - Class in org.glassfish.grizzly
Builder
AbstractSocketConnectorHandler.Builder() - Constructor for class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
AbstractStreamReader - Class in org.glassfish.grizzly.streams
Each method reads data from the current ByteBuffer.
AbstractStreamReader(Connection, Input) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamReader
Create a new ByteBufferReader.
AbstractStreamWriter - Class in org.glassfish.grizzly.streams
Write the primitive Java type to the current ByteBuffer.
AbstractStreamWriter(Connection, Output) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamWriter
Create a new ByteBufferWriter.
AbstractStreamWriter.DisposeBufferCompletionHandler - Class in org.glassfish.grizzly.streams
 
AbstractStreamWriter.DisposeBufferCompletionHandler(Buffer) - Constructor for class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
AbstractThreadPool - Class in org.glassfish.grizzly.threadpool
Abstract ExecutorService implementation.
AbstractThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
AbstractThreadPool.Worker - Class in org.glassfish.grizzly.threadpool
 
AbstractThreadPool.Worker() - Constructor for class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
AbstractTransformer<K,L> - Class in org.glassfish.grizzly
 
AbstractTransformer() - Constructor for class org.glassfish.grizzly.AbstractTransformer
 
AbstractTransformer.LastResultAwareState<K,L> - Class in org.glassfish.grizzly
 
AbstractTransformer.LastResultAwareState() - Constructor for class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
AbstractTransport - Class in org.glassfish.grizzly
Abstract Transport.
AbstractTransport(String) - Constructor for class org.glassfish.grizzly.AbstractTransport
 
AbstractWriter<L> - Class in org.glassfish.grizzly
Abstract class, which provides transitive dependencies for overloaded Writer methods.
AbstractWriter() - Constructor for class org.glassfish.grizzly.AbstractWriter
 
accept() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Accept a Connection.
accept() - Method in interface org.glassfish.grizzly.SocketAcceptor
Accept a Connection
acceptAsync() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Asynchronously accept a Connection
ACCEPTED_202 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
ACK_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
acknowledge() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Acknowledge a HTTP Expect header.
acknowledged() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Mark this packet as having been acknowledged.
acquireBuffer(Connection) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
ACTIVE_ATTRIBUTE_NAME - Static variable in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible for tracking Connection activity and closing Connection ones it becomes idle for certain amount of time.
ActivityCheckFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter(DelayedExecutor, long, TimeUnit, ActivityCheckFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter(DelayedExecutor, DelayedExecutor.Worker<Connection>, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.ActivityCheckFilter
 
ActivityCheckFilter.TimeoutHandler - Interface in org.glassfish.grizzly.utils
 
adapt(Integer) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.HandshakeCompletionHandler
 
adapt(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
adapt(K) - Method in interface org.glassfish.grizzly.utils.GenericAdapter
 
add(ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
add(int, ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
add(E) - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
add(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
add(Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(int, Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
add(HttpRequestPacket, long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Add a resource to the cache.
add(HttpRequestPacket, File) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Add a File resource to the cache.
add(HttpRequestPacket, File, long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Add a resource to the cache.
add(String, String) - Static method in class org.glassfish.grizzly.http.util.MimeType
Associates the specified extension and content type
add(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(E, int, int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
add(ArraySet<T>) - Method in class org.glassfish.grizzly.utils.ArraySet
Add all the elements from the source ArraySet.
add(T) - Method in class org.glassfish.grizzly.utils.ArraySet
add(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
add(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
add(K, V) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Add a value to the current list of values for the supplied key.
add(K, V) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Add a value to the current list of values for the supplied key.
addAfterServiceListener(AfterServiceListener) - Method in class org.glassfish.grizzly.http.server.Request
Add the listener, which will be notified, once Request processing will be finished.
addAll(Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(int, Collection<? extends ProcessorSelector>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
addAll(Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(int, Filter[]) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(int, List<Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(FilterChainBuilder) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addAll(Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(int, Collection<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
addAll(T...) - Method in class org.glassfish.grizzly.utils.ArraySet
Add the element(s) to the set.
addAll(Collection<? extends T>) - Method in class org.glassfish.grizzly.utils.ArraySet
addAll(K, V...) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Add multiple values to the current list of values for the supplied key.
addAll(K, List<V>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Add all the values from the supplied value list to the current list of values for the supplied key.
addAll(K, V...) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Add multiple values to the current list of values for the supplied key.
addAll(K, List<V>) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Add all the values from the supplied value list to the current list of values for the supplied key.
addCachingHeaders(Response, File) - Static method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
addCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Closeable
Add the CloseListener, which will be notified once the stream will be closed.
addCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Connection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
addCloseListener(CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
Add the Connection.CloseListener, which will be notified once Connection will be closed.
addCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
addCompletionHandler(CompletionHandler<R>) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionHandler(CompletionHandler<R>) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Adds a CompletionHandler, which will be notified once the asynchronous computation, represented by this Future, is complete.
addCompletionListener(FilterChainContext.CompletionListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Add the FilterChainContext.CompletionListener, which will be notified, when this FilterChainContext processing will be completed.
addContentEncoding(ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Adds the specified ContentEncoding to the HttpCodecFilter.
addContentEncoding(ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpHeader
 
addContext(String, String, Object, String[], NamingContext) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new Context to an existing Host.
addContext(String, String, Object, String[], NamingContext, List<AlternateDocBase>) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new Context to an existing Host.
addCookie(Cookie) - Method in class org.glassfish.grizzly.http.server.Request
Add a Cookie to the set of Cookies associated with this Request.
addCookie(Cookie) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified Cookie to those that will be included with this Response.
addCopyListener(FilterChainContext.CopyListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Add the FilterChainContext.CopyListener, which will be notified, right after this FilterChainContext.copy() is called.
addDateHeader(String, long) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified date header to the specified value.
addDateHeader(Header, long) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified date header to the specified value.
addDocRoot(String) - Method in class org.glassfish.grizzly.http.server.CLStaticHttpHandler
Adds doc root (path prefix), which will be used to look up resources.
addDocRoot(String) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Add the directory to the list of directories where files will be serviced from.
addDocRoot(File) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Add the directory to the list of directories where files will be serviced from.
addEndpoint(Class<?>) - Method in interface javax.websocket.server.ServerContainer
Deploys the given annotated endpoint into this ServerContainer during the initialization phase of deploying the application.
addEndpoint(ServerEndpointConfig) - Method in interface javax.websocket.server.ServerContainer
 
addException(Exception) - Method in class org.glassfish.tyrus.core.ErrorCollector
Add Exception to the collector.
addFirst(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addFirst(K, V) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Add a value to the first position in the current list of values for the supplied key.
addFirst(K, V) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Add a value to the first position in the current list of values for the supplied key.
addFirstNull(List<V>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Define the behavior for adding a null values to the first position in the value list.
addFirstNull(List<String>) - Method in class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
addHandler(HttpHandler, String[]) - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
Add a HttpHandler and its associated array of mapping.
addHandshakeListener(SSLBaseFilter.HandshakeListener) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
addHeader(String, String) - Method in class org.glassfish.grizzly.http.HttpHeader
Add the HTTP mime header.
addHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
Add the HTTP mime header.
addHeader(Header, String) - Method in class org.glassfish.grizzly.http.HttpHeader
Add the HTTP mime header.
addHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
Add the HTTP mime header.
addHeader(String, String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Add the HTTP mime header.
addHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpTrailer
Add the HTTP mime header.
addHeader(Header, String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Add the HTTP mime header.
addHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpTrailer
Add the HTTP mime header.
addHeader(String, String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Add the HTTP mime header.
addHeader(String, HeaderValue) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Add the HTTP mime header.
addHeader(Header, String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Add the HTTP mime header.
addHeader(Header, HeaderValue) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Add the HTTP mime header.
addHeader(String, String) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified header to the specified value.
addHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified header to the specified value.
addHeader(Header, String) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified header to the specified value.
addHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified header to the specified value.
addHeapSize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
addHost(String, String[], Object) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new host to the mapper.
addHttpHandler(HttpHandler, String...) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Adds the specified HttpHandler with its associated mapping(s).
addIntHeader(String, int) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified integer header to the specified value.
addIntHeader(Header, int) - Method in class org.glassfish.grizzly.http.server.Response
Add the specified integer header to the specified value.
addJmxEventListener(JmxEventListener) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Add a JmxEventListener which will be notified when the HttpServer is started and JMX was enabled prior to starting or if the HttpServer was started with JMX disabled, but JMX was enabled at a later point in time.
addLast(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
addLifeCycleListener(IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.Context
 
addListener(NetworkListener) - Method in class org.glassfish.grizzly.http.server.HttpServer
Adds the specified listener to the server instance.
addLocale(Locale) - Method in class org.glassfish.grizzly.http.server.Request
Add a Locale to the set of preferred Locales for this Request.
addMappedMemorySize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
addMessageHandler(MessageHandler) - Method in interface javax.websocket.Session
Register to handle to incoming messages in this conversation.
addMessageHandler(MessageHandler) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Not supported (yet?).
addMessageHandler(MessageHandler) - Method in class org.glassfish.tyrus.core.TyrusSession
 
addMonitoringProbe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Add the ConnectionProbe, which will be notified about Connection life-cycle events.
addNull(List<V>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Define the behavior for adding a null values to the value list.
addNull(List<String>) - Method in class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
AddOn - Interface in org.glassfish.grizzly.http.server
The HttpServer addon interface, responsible for adding features like WebSockets, Comet to HttpServer.
addParameter(String, String[]) - Method in class org.glassfish.grizzly.http.server.Request
Add a parameter name and corresponding set of values to this Request.
addParameter(String, String) - Method in class org.glassfish.grizzly.http.util.Parameters
 
addParameterValues(String, String[]) - Method in class org.glassfish.grizzly.http.util.Parameters
 
addProbes(E...) - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Add the monitoring probes, which will be notified about object's lifecycle events.
addProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Add the monitoring probes, which will be notified about object's lifecycle events.
addRecord(Connection, Buffer, CompletionHandler, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
addRecord(Connection, Buffer, CompletionHandler, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
addSafeCharacter(char) - Method in class org.glassfish.grizzly.http.util.UEncoder
 
addSessionCookieInternal(Cookie) - Method in class org.glassfish.grizzly.http.server.Response
Special method for adding a session cookie as we should be overriding any previous
addShutdownListener(GracefulShutdownListener) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
addShutdownListener(GracefulShutdownListener) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
addShutdownListener(GracefulShutdownListener) - Method in interface org.glassfish.grizzly.Transport
Adds a GracefulShutdownListener which will be called when Transport.shutdown() is called to enable graceful shutdown of transports.
addToFileCache(Request, Response, File) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
addTransferEncoding(TransferEncoding) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Adds the specified TransferEncoding to the HttpCodecFilter.
addUnique(T[], T) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Add unique element to the array.
addUnique(T[], T, boolean) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Add unique element to the array.
addValue(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Create a new named header , return the MessageBytes container for the new value
addValue(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Create a new named header , return the MessageBytes container for the new value
addValue(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Create a new named header using un-translated byte[].
addValue(Buffer, int, int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Create a new named header using un-translated Buffer.
addWrapper(String, String, String, Object) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new Wrapper to an existing Context.
addWrapper(String, String, String, Object, boolean) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new Wrapper to an existing Context.
addWrapper(String, String, String, Object, boolean, String, boolean) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a new Wrapper to an existing Context.
addWrapper(String, Object) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Add a wrapper to the context associated with this wrapper.
addWrapper(String, Object, boolean, boolean) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
addWrapper(Mapper.Context, String, Object) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
addWrapper(Mapper.Context, String, Object, boolean, boolean) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
addWrapper(Mapper.Context, String, Object, boolean, String, boolean) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Adds a wrapper to the given context.
advance() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Advance the current parsing position by one, if we are not already past the end of the string.
afterExecute(AbstractThreadPool.Worker, Thread, Runnable, Throwable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method invoked upon completion of execution of the given Runnable.
afterResponse(HandshakeResponse) - Method in class javax.websocket.ClientEndpointConfig.Configurator
This method is called by the implementation after it has received a handshake response from the server as a result of a handshake interaction it initiated.
AfterServiceListener - Interface in org.glassfish.grizzly.http.server
The listener, which could be registered on a Request using Request.addAfterServiceListener(org.glassfish.grizzly.http.server.AfterServiceListener) and be notified once the Request processing will be completed.
afterServicesList - Variable in class org.glassfish.grizzly.http.server.Request
 
aggregate(TaskQueue<AsyncWriteQueueRecord>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Aggregates records in a queue to be written as one chunk.
aggregate(TaskQueue<AsyncWriteQueueRecord>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
Aggregates records in a queue to be written as one chunk.
AggregatorAddOn - Class in org.glassfish.grizzly.http.server.util
AggregatorAddOn installs AggregatorFilter into HttpServer FilterChain.
AggregatorAddOn() - Constructor for class org.glassfish.grizzly.http.server.util.AggregatorAddOn
 
ALL - Static variable in class org.glassfish.tyrus.core.coder.PrimitiveDecoders
 
ALL_INSTANCES - Static variable in class org.glassfish.tyrus.core.coder.PrimitiveDecoders
 
allocate(int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
allocate(int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
allocate(int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
allocate(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocated Buffer of the required size.
allocate(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Allocated Buffer of the required size.
allocate(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Allocated Buffer of the required size.
allocate(int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
For this implementation, this method simply calls through to PooledMemoryManager.allocateAtLeast(int);
allocate(int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
allocate(int) - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
allocateAndReadBuffer(TCPNIOConnection) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocated Buffer at least of the provided size.
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Allocated Buffer at least of the provided size.
allocateAtLeast(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Allocated Buffer at least of the provided size.
allocateAtLeast(int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Allocates a buffer of at least the size requested.
allocateByteBuffer(int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
allocateByteBuffer(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocates ByteBuffer of required size.
allocateByteBuffer(MemoryManager, int) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
allocateByteBuffer0(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
allocateByteBufferAtLeast(int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
allocateByteBufferAtLeast(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Allocates ByteBuffer of required size.
allocateFromPool(ThreadLocalPool, int) - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Allocate a Buffer using the provided ThreadLocalPool.
allocateHeapBuffer(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
allocateHeapBufferAtLeast(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
allocateNewBuffer(MemoryManager, int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
ALLOW_BACKSLASH - Static variable in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
 
ALLOW_ENCODED_SLASH - Static variable in class org.glassfish.grizzly.http.util.UDecoder
 
allowBufferDispose() - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose(boolean) - Method in interface org.glassfish.grizzly.Buffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
allowBufferDispose - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowBufferDispose(boolean) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
allowInternalBuffersDispose(boolean) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
allowInternalBuffersDispose() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
allowReplacement() - Static method in class org.glassfish.grizzly.http.server.util.Mapper
alreadyQuoted(String) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
ALT_DD_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which we store the alternate deployment descriptor for this web application
AlternateDocBase - Class in org.glassfish.grizzly.http.server.util
 
AlternateDocBase() - Constructor for class org.glassfish.grizzly.http.server.util.AlternateDocBase
 
alternateDocBases - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
ALWAYS_ADD_EXPIRES - Static variable in class org.glassfish.grizzly.http.util.CookieUtils
If set to false, we don't use the IE6/7 Max-Age/Expires work around
AnnotatedEndpoint - Class in org.glassfish.tyrus.core
Endpoint descendant which represents deployed annotated endpoint.
appCommitted - Variable in class org.glassfish.grizzly.http.server.Response
The application commit flag.
append(T) - Method in interface org.glassfish.grizzly.Appendable
 
append(E, E) - Method in interface org.glassfish.grizzly.Appender
 
append(HttpContent) - Method in class org.glassfish.grizzly.http.HttpContent
 
append(HttpContent) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Appends the specified Buffer to the internal composite Buffer.
append(BufferChunk) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
append(char) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
append(byte) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
append(ByteChunk) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
append(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Add data to the buffer
append(char) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
append(CharChunk) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
append(char[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Add data to the buffer
append(StringBuffer) - Method in class org.glassfish.grizzly.http.util.CharChunk
Add data to the buffer
append(String) - Method in class org.glassfish.grizzly.http.util.CharChunk
Append a string to the buffer
append(String, int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Append a string to the buffer
append(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
append(Buffer) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
append(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
Appendable<T> - Interface in org.glassfish.grizzly
 
appendBuffers(MemoryManager, Buffer, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Append two Buffers.
appendBuffers(MemoryManager, Buffer, Buffer, boolean) - Static method in class org.glassfish.grizzly.memory.Buffers
Append two Buffers.
appendBuffers(ByteBuffer, ByteBuffer, int, int) - Static method in class org.glassfish.tyrus.core.Utils
Concatenates two buffers into one.
Appender<E> - Interface in org.glassfish.grizzly
 
appendRequestURL(Request, StringBuilder) - Static method in class org.glassfish.grizzly.http.server.Request
Appends the reconstructed URL the client used to make the request.
appendRequestURL(Request, StringBuffer) - Static method in class org.glassfish.grizzly.http.server.Request
Appends the reconstructed URL the client used to make the request.
APPLICATION_DATA_TOO_LONG(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
{0} applicationData exceeded the maximum allowed payload of 125 bytes.
applyDecoding(HttpHeader) - Method in interface org.glassfish.grizzly.http.EncodingFilter
 
applyDecoding(HttpHeader) - Method in class org.glassfish.grizzly.http.server.CompressionEncodingFilter
 
applyEncoding(HttpHeader) - Method in interface org.glassfish.grizzly.http.EncodingFilter
 
applyEncoding(HttpHeader) - Method in class org.glassfish.grizzly.http.server.CompressionEncodingFilter
 
ARGUMENT_NOT_NULL(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Argument ''{0}'' cannot be null.
array() - Method in interface org.glassfish.grizzly.Buffer
Returns the byte array that backs this buffer (optional operation).
array() - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
array() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
array() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
array() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
arrayOffset() - Method in interface org.glassfish.grizzly.Buffer
Returns the offset within this buffer's backing array of the first element of the buffer (optional operation).
arrayOffset - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
arrayOffset() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
arrayOffset() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
arrayOffset() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
ArraySet<T> - Class in org.glassfish.grizzly.utils
The thread safe set implementation, which uses array to hold its elements.
ArraySet(Class<T>) - Constructor for class org.glassfish.grizzly.utils.ArraySet
 
ArraySet(Class<T>, boolean) - Constructor for class org.glassfish.grizzly.utils.ArraySet
 
ArrayUtils - Class in org.glassfish.grizzly.utils
Set of utility methods to work with Arrays.
ArrayUtils() - Constructor for class org.glassfish.grizzly.utils.ArrayUtils
 
Ascii - Class in org.glassfish.grizzly.http.util
This class implements some basic ASCII character handling functions.
Ascii() - Constructor for class org.glassfish.grizzly.http.util.Ascii
 
ASCII_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
 
asClientCookieBuffer() - Method in class org.glassfish.grizzly.http.Cookie
 
asClientCookieBuffer(MemoryManager) - Method in class org.glassfish.grizzly.http.Cookie
 
asClientCookieString() - Method in class org.glassfish.grizzly.http.Cookie
 
asClosed(PathPattern) - Static method in class org.glassfish.tyrus.core.uri.internal.PathPattern
Return a new path pattern with a same path template but a closed right hand path.
asReadOnlyBuffer() - Method in interface org.glassfish.grizzly.Buffer
Creates a new, read-only Buffer that shares this buffer's content.
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
asReadOnlyBuffer() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
assertOpen() - Method in interface org.glassfish.grizzly.Connection
Checks if this Connection is open and ready to be used.
assertOpen() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
asServerCookieBuffer() - Method in class org.glassfish.grizzly.http.Cookie
 
asServerCookieBuffer(MemoryManager) - Method in class org.glassfish.grizzly.http.Cookie
 
asServerCookieString() - Method in class org.glassfish.grizzly.http.Cookie
 
asyncConnectToServer(Class<?>, URI) - Method in class org.glassfish.tyrus.client.ClientManager
asyncConnectToServer(Class<? extends Endpoint>, ClientEndpointConfig, URI) - Method in class org.glassfish.tyrus.client.ClientManager
asyncConnectToServer(Endpoint, ClientEndpointConfig, URI) - Method in class org.glassfish.tyrus.client.ClientManager
asyncConnectToServer(Object, URI) - Method in class org.glassfish.tyrus.client.ClientManager
asyncInput() - Method in class org.glassfish.grizzly.http.server.Request
Deprecated.
will always return true
AsyncQueue - Interface in org.glassfish.grizzly.asyncqueue
Common interface for AsyncQueue processors.
AsyncQueue.AsyncResult - Enum in org.glassfish.grizzly.asyncqueue
 
AsyncQueueEnabledTransport - Interface in org.glassfish.grizzly.asyncqueue
Interface, which Transports should implement if they support AsyncQueues.
AsyncQueueIO<L> - Interface in org.glassfish.grizzly.asyncqueue
Class encapsulates asynchronous queue implementation: AsyncQueueReader, AsyncQueueWriter.
asyncQueueIO - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Transport AsyncQueueIO
AsyncQueueIO.Factory - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueIO.Factory() - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
AsyncQueueIO.ImmutableAsyncQueueIO<L> - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueIO.MutableAsyncQueueIO<L> - Class in org.glassfish.grizzly.asyncqueue
 
AsyncQueueReader<L> - Interface in org.glassfish.grizzly.asyncqueue
The AsyncQueue, which implements asynchronous read queue.
AsyncQueueRecord<R> - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue element unit
AsyncQueueRecord() - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
AsyncQueueRecord(Connection, Object, CompletionHandler) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
AsyncQueueWriter<L> - Interface in org.glassfish.grizzly.asyncqueue
The AsyncQueue, which implements asynchronous write queue.
asyncReadQueue - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
AsyncReadQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue read element unit
asyncWriteQueue - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
AsyncWriteQueueRecord - Class in org.glassfish.grizzly.asyncqueue
AsyncQueue write element unit
AsyncWriteQueueRecord(Connection, WritableMessage, CompletionHandler, Object, PushBackHandler, boolean) - Constructor for class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
attach() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
attachToSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
Attribute<T> - Class in org.glassfish.grizzly.attributes
Class used to define dynamic typed attributes on AttributeHolder instances.
Attribute(AttributeBuilder, String, int, T) - Constructor for class org.glassfish.grizzly.attributes.Attribute
 
Attribute(AttributeBuilder, String, int, NullaryFunction<T>) - Constructor for class org.glassfish.grizzly.attributes.Attribute
 
attributeBuilder - Variable in class org.glassfish.grizzly.AbstractTransformer
 
attributeBuilder - Variable in class org.glassfish.grizzly.AbstractTransport
Transport AttributeBuilder, which will be used to create Attributes
AttributeBuilder - Interface in org.glassfish.grizzly.attributes
AttributeBuilder is responsible for creating and indexing Attributes.
attributeBuilder - Variable in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
attributeBuilder - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
AttributeHolder - Interface in org.glassfish.grizzly.attributes
Interface declares common functionality for objects, which have associated Attributes.
attributes - Variable in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
attributes - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
The attributes associated with this Request, keyed by attribute name.
attributes() - Method in class org.glassfish.grizzly.http.server.Session
Return a ConcurrentMap of attributes.
attributes - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
AttributeStorage - Interface in org.glassfish.grizzly.attributes
AttributeStorage provides access to a AttributeHolder, where application can store Attributes.
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
attributeStorage - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
AUTHORIZATION_HEADER - Static variable in class org.glassfish.grizzly.http.server.Constants
Default header names.
authType() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the authentication type used for this Request.
AUTO_SIZE - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Constant set via AsyncQueueWriter.setMaxPendingBytesPerConnection(int) means the async write queue size will be configured automatically per NIOConnection depending on connections write buffer size.
available() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
available() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Return the number of bytes available for get calls.
available() - Method in interface org.glassfish.grizzly.streams.StreamReader
Return the number of bytes available for get calls.
available() - Method in class org.glassfish.grizzly.utils.BufferInputStream
availableChar() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
awaitTermination(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
awaitTermination(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 

B

B2CConverter - Class in org.glassfish.grizzly.http.util
Efficient conversion of bytes to character .
B2CConverter() - Constructor for class org.glassfish.grizzly.http.util.B2CConverter
 
B2CConverter(String) - Constructor for class org.glassfish.grizzly.http.util.B2CConverter
Create a converter, with bytes going to a byte buffer
B2CConverterBlocking - Class in org.glassfish.grizzly.http.util
Efficient conversion of bytes to character .
B2CConverterBlocking() - Constructor for class org.glassfish.grizzly.http.util.B2CConverterBlocking
 
B2CConverterBlocking(String) - Constructor for class org.glassfish.grizzly.http.util.B2CConverterBlocking
Create a converter, with bytes going to a byte buffer
BAD_GATEWAY_502 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
BAD_REQUEST_400 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
Base - Class in org.glassfish.grizzly.compression.lzma.impl
Base
Base() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Base
 
Base64Utils - Class in org.glassfish.grizzly.http.util
 
Base64Utils() - Constructor for class org.glassfish.grizzly.http.util.Base64Utils
 
Base64Utils - Class in org.glassfish.tyrus.core
 
Base64Utils() - Constructor for class org.glassfish.tyrus.core.Base64Utils
 
BaseContainer - Class in org.glassfish.tyrus.core
Base WebSocket container.
BaseContainer() - Constructor for class org.glassfish.tyrus.core.BaseContainer
 
BaseFilter - Class in org.glassfish.grizzly.filterchain
Provides empty implementation for Filter processing methods.
BaseFilter() - Constructor for class org.glassfish.grizzly.filterchain.BaseFilter
 
bb - Variable in class org.glassfish.grizzly.http.util.C2BConverter
 
beforeExecute(AbstractThreadPool.Worker, Thread, Runnable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method invoked prior to executing the given Runnable in the given thread.
beforeRequest(Map<String, List<String>>) - Method in class javax.websocket.ClientEndpointConfig.Configurator
This method is called by the implementation after it has formulated the handshake request that will be used to initiate the connection to the server, but before it has sent any part of the request.
bigEndian - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
BINARY_MESSAGE_HANDLER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Binary message handler not found.
BINARY_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Binary message received out of order.
BinaryFrame - Class in org.glassfish.tyrus.core.frame
Binary frame representation.
BinaryFrame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.BinaryFrame
Constructor.
BinaryFrame(Frame, boolean) - Constructor for class org.glassfish.tyrus.core.frame.BinaryFrame
Constructor.
BinaryFrame(byte[], boolean, boolean) - Constructor for class org.glassfish.tyrus.core.frame.BinaryFrame
Constructor.
BinaryNIOInputSource - Interface in org.glassfish.grizzly.http.io
Adds the ability for binary based InputSources to obtain the incoming Buffer directly without having to use intermediate objects to copy the data to.
BinaryNIOOutputSink - Interface in org.glassfish.grizzly.http.io
Adds the ability for binary based OutputSinks to write a Buffer instead of having to convert to those types supported by OutputStream.
binarySearch(int[], int, int, int) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
 
bind(int) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Binds Transport to the specific port on localhost.
bind(String, int) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Binds Transport to the specific host and port.
bind(String, int, int) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Binds Transport to the specific host and port.
bind(String, PortRange, int) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Binds Transport to the specific host, and port within a PortRange.
bind(HttpRequestPacket, HttpResponsePacket) - Method in class org.glassfish.grizzly.http.HttpBaseFilter
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler
 
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler
 
bind(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific port on localhost.
bind(String, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host and port.
bind(String, int, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host and port.
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific SocketAddress.
bind(String, PortRange, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds Transport to the specific host, and port within a PortRange.
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
bind(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific port on localhost.
bind(String, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host and port.
bind(String, int, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host and port.
bind(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific SocketAddress.
bind(String, PortRange, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Binds Transport to the specific host, and port within a PortRange.
bind(int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific port on localhost.
bind(String, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host and port.
bind(String, int, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host and port.
bind(String, PortRange, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific host, and port within a PortRange.
bind(SocketAddress) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific SocketAddress.
bind(SocketAddress, int) - Method in interface org.glassfish.grizzly.SocketBinder
Binds Transport to the specific SocketAddress.
bindToInherited() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler
 
bindToInherited() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Binds the Transport to the channel inherited from the entity that created this Java virtual machine.
bindToInherited() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
bindToInherited() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
bindToInherited() - Method in interface org.glassfish.grizzly.SocketBinder
Binds the Transport to the channel inherited from the entity that created this Java virtual machine.
BinTree - Class in org.glassfish.grizzly.compression.lzma.impl.lz
BinTree
BinTree() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
BitTreeDecoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
BitTreeDecoder
BitTreeDecoder(int) - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
BitTreeEncoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
BitTreeEncoder
BitTreeEncoder(int) - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
block(InetAddress, NetworkInterface, InetAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Blocks multicast datagrams from the given source address.
broadcast(String) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Broadcasts text message to all connected clients.
broadcast(ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Broadcasts binary message to all connected clients.
broadcast(String) - Method in class org.glassfish.tyrus.core.TyrusSession
Broadcasts text message to all connected clients.
broadcast(ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusSession
Broadcasts binary message to all connected clients.
broadcastBinary(String, byte[]) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Broadcast binary message.
BroadcastListener - Interface in org.glassfish.tyrus.core.cluster
Broadcast listener.
broadcastText(String, String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Broadcast text message.
Buffer - Interface in org.glassfish.grizzly
JDK ByteBuffer was taken as base for Grizzly Buffer interface, but Buffer has several extensions: it's possible to prepend some data to a Buffer and release Buffer, when it's not required any more.
BUFFER_OVERFLOW() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Buffer overflow.
BUFFER_OVERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
BUFFER_OVERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
BUFFER_UNDERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
BUFFER_UNDERFLOW_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
BufferArray - Class in org.glassfish.grizzly.memory
 
BufferChunk - Class in org.glassfish.grizzly.http.util
Buffer chunk representation.
BufferChunk() - Constructor for class org.glassfish.grizzly.http.util.BufferChunk
 
BUFFERED_FILTER - Static variable in class org.glassfish.grizzly.http.server.Constants
Buffered filter (input)
BufferedInput - Class in org.glassfish.grizzly.streams
 
BufferedInput() - Constructor for class org.glassfish.grizzly.streams.BufferedInput
 
BufferedOutput - Class in org.glassfish.grizzly.streams
 
BufferedOutput() - Constructor for class org.glassfish.grizzly.streams.BufferedOutput
 
BufferedOutput(int) - Constructor for class org.glassfish.grizzly.streams.BufferedOutput
 
BufferInputStream - Class in org.glassfish.grizzly.utils
InputStream implementation over Grizzly Buffer.
BufferInputStream(Buffer) - Constructor for class org.glassfish.grizzly.utils.BufferInputStream
Create the InputStream over Grizzly Buffer.
BufferInputStream(Buffer, int, int) - Constructor for class org.glassfish.grizzly.utils.BufferInputStream
Create the InputStream over Grizzly Buffer.
BufferOutputStream - Class in org.glassfish.grizzly.utils
OutputStream implementation to write to a Buffer.
BufferOutputStream(MemoryManager) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream without initial Buffer.
BufferOutputStream(MemoryManager, Buffer) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream using passed Buffer as initial.
BufferOutputStream(MemoryManager, Buffer, boolean) - Constructor for class org.glassfish.grizzly.utils.BufferOutputStream
Creates the BufferOutputStream using passed Buffer as initial.
Buffers - Class in org.glassfish.grizzly.memory
Class has useful methods to simplify the work with Buffers.
Buffers() - Constructor for class org.glassfish.grizzly.memory.Buffers
 
BuffersBuffer - Class in org.glassfish.grizzly.memory
 
BuffersBuffer(MemoryManager, Buffer[], int, boolean) - Constructor for class org.glassfish.grizzly.memory.BuffersBuffer
 
bufferSize - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 
build() - Method in class javax.websocket.ClientEndpointConfig.Builder
Builds a configuration object using the attributes set on this builder.
build() - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Builds the configuration object using the current attributes that have been set on this builder object.
build() - Method in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
build() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
build() - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
build() - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder.StatelessFilterChainBuilder
 
build() - Method in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
build() - Method in class org.glassfish.grizzly.http.HttpBrokenContent.Builder
Build the HttpTrailer message.
build() - Method in class org.glassfish.grizzly.http.HttpContent.Builder
Build the HttpContent message.
build() - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
 
build() - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Build the HttpRequestPacket message.
build() - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
Build the HttpResponsePacket message.
build() - Method in class org.glassfish.grizzly.http.HttpTrailer.Builder
Build the HttpTrailer message.
build() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
build() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
build() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
build() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
build() - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Build new frame.
build() - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Build RequestContext from given properties.
builder - Variable in class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
FilterChainBuilder, responsible for creating FilterChain instances
builder(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpBrokenContent
Returns HttpTrailer builder.
builder(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpContent
Returns HttpContent builder.
builder() - Static method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns HttpRequestPacket builder.
builder(HttpRequestPacket) - Static method in class org.glassfish.grizzly.http.HttpResponsePacket
Returns HttpResponsePacket builder.
builder(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpTrailer
Returns HttpTrailer builder.
builder(TCPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler
 
builder(TCPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
Return the TCPNIOConnectorHandler builder.
builder(UDPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
builder(UDPNIOTransport) - Static method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
Return the UDPNIOConnectorHandler builder.
builder() - Static method in class org.glassfish.tyrus.core.frame.Frame
Create new Frame.Builder.
builder(Frame) - Static method in class org.glassfish.tyrus.core.frame.Frame
Create new Frame.Builder based on provided frame.
bulk(CompositeBuffer.BulkOperation) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Iterates over Buffer bytes from Buffer.position() to Buffer.limit() and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Iterates over Buffer bytes from position to limit and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Iterates over Buffer bytes from Buffer.position() to Buffer.limit() and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bulk(CompositeBuffer.BulkOperation, int, int) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Iterates over Buffer bytes from position to limit and lets CompositeBuffer.BulkOperation examine/change the buffer content;
bundleChanged(BundleEvent) - Method in class org.glassfish.tyrus.core.OsgiRegistry
 
byteBuffer - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
ByteBufferArray - Class in org.glassfish.grizzly.memory
 
ByteBufferAware - Interface in org.glassfish.grizzly.memory
 
ByteBufferManager - Class in org.glassfish.grizzly.memory
The simple Buffer manager implementation, which works as wrapper above ByteBuffers.
ByteBufferManager() - Constructor for class org.glassfish.grizzly.memory.ByteBufferManager
 
ByteBufferManager(boolean) - Constructor for class org.glassfish.grizzly.memory.ByteBufferManager
 
ByteBufferManager(boolean, int, int) - Constructor for class org.glassfish.grizzly.memory.ByteBufferManager
 
ByteBufferManager.SmallByteBufferWrapper - Class in org.glassfish.grizzly.memory
ByteBufferWrapper implementation, which supports trimming.
ByteBufferWrapper - Class in org.glassfish.grizzly.memory
Buffer implementation, which uses the ByteBuffer underneath.
ByteBufferWrapper() - Constructor for class org.glassfish.grizzly.memory.ByteBufferWrapper
 
ByteBufferWrapper(ByteBuffer) - Constructor for class org.glassfish.grizzly.memory.ByteBufferWrapper
 
ByteChunk - Class in org.glassfish.grizzly.http.util
This class is used to represent a chunk of bytes, and utilities to manipulate byte[].
ByteChunk() - Constructor for class org.glassfish.grizzly.http.util.ByteChunk
Creates a new, uninitialized ByteChunk object.
ByteChunk(int) - Constructor for class org.glassfish.grizzly.http.util.ByteChunk
 
ByteChunk.ByteInputChannel - Interface in org.glassfish.grizzly.http.util
 
ByteChunk.ByteOutputChannel - Interface in org.glassfish.grizzly.http.util
 

C

c - Variable in class org.glassfish.tyrus.core.ReflectionHelper.ClassTypePair
The class.
c - Variable in class org.glassfish.tyrus.core.ReflectionHelper.TypeClassPair
 
C2BConverter - Class in org.glassfish.grizzly.http.util
Efficient conversion of character to bytes.
C2BConverter(ByteChunk, String) - Constructor for class org.glassfish.grizzly.http.util.C2BConverter
Create a converter, with bytes going to a byte buffer
C2BConverter(String) - Constructor for class org.glassfish.grizzly.http.util.C2BConverter
Create a converter
Cacheable - Interface in org.glassfish.grizzly
 
CacheableDataChunk - Class in org.glassfish.grizzly.http.util
DataChunk implementation, which could be cached in the thread cache.
CacheableDataChunk() - Constructor for class org.glassfish.grizzly.http.util.CacheableDataChunk
 
canBeAggregated() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
cancel() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Instructs Grizzly to cancel this message write and release message associated resources.
cancel() - Method in class org.glassfish.grizzly.http.server.Response
Deprecated.
cancel(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Do nothing.
cancel(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
cancel(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
cancel(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeregisterChannelOperation
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterChannelOperation
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
cancel() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RunnableTask
 
cancel(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
cancel() - Method in interface org.glassfish.grizzly.nio.SelectorHandlerTask
 
cancel(boolean) - Method in class org.glassfish.tyrus.core.TyrusFuture
 
cancelled() - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was cancelled.
cancelled() - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was cancelled.
cancelled() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
cancelled() - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
cancelled() - Method in class org.glassfish.tyrus.spi.CompletionHandler
The operation was cancelled.
canCompressHttpResponse(HttpResponsePacket, CompressionConfig, String[]) - Static method in class org.glassfish.grizzly.http.server.CompressionEncodingFilter
Returns true if the HttpResponsePacket could be compressed, or false otherwise.
canServeCompressed(HttpRequestPacket) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
Returns true if this entry could be served compressed as response to this (passed) specific HttpRequestPacket.
canWrite(Connection<L>, int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Deprecated.
the size parameter will be ignored, use Writer.canWrite(org.glassfish.grizzly.Connection) instead.
canWrite(int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Deprecated.
the length parameter will be ignored. Please use OutputBuffer.canWrite().
canWrite() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
canWrite(Connection<SocketAddress>, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Deprecated.
canWrite(Connection<SocketAddress>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
canWrite(Connection) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Return true if the connection has not exceeded it's maximum size in bytes of pending writes, otherwise false.
canWrite() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
canWrite(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Deprecated.
canWrite() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
canWrite(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Deprecated.
canWrite() - Method in interface org.glassfish.grizzly.OutputSink
 
canWrite(int) - Method in interface org.glassfish.grizzly.OutputSink
Deprecated.
the length parameter will be ignored. Pls. use OutputSink.canWrite().
canWrite(Connection<L>) - Method in interface org.glassfish.grizzly.Writer
Return true if the connection has not exceeded it's maximum size in bytes of pending writes, otherwise false.
canWriteChar(int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Deprecated.
cap - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
capacity() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's capacity.
capacity() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
capacity() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
capacity() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
CERTIFICATE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the client certificate chain.
CERTIFICATES_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we store the array of X509Certificate objects representing the certificate chain presented by our client, if any.
ChainProcessorSelector - Class in org.glassfish.grizzly
ProcessorSelector implementation, which acts like wrapper for chain of ProcessorSelectors.
ChainProcessorSelector() - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
ChainProcessorSelector(ProcessorSelector...) - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
ChainProcessorSelector(List<ProcessorSelector>) - Constructor for class org.glassfish.grizzly.ChainProcessorSelector
 
changed(E) - Method in interface org.glassfish.grizzly.ChangeListener
 
ChangeListener<E> - Interface in org.glassfish.grizzly
 
changeSessionId() - Method in class org.glassfish.grizzly.http.server.Request
Change the session id of the current session associated with this request and return the new session id.
channel - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
CharChunk - Class in org.glassfish.grizzly.http.util
Utilities to manipluate char chunks.
CharChunk() - Constructor for class org.glassfish.grizzly.http.util.CharChunk
Creates a new, uninitialized CharChunk object.
CharChunk(int) - Constructor for class org.glassfish.grizzly.http.util.CharChunk
 
CharChunk.CharInputChannel - Interface in org.glassfish.grizzly.http.util
 
CharChunk.CharOutputChannel - Interface in org.glassfish.grizzly.http.util
When we need more space we'll either grow the buffer ( up to the limit ) or send it to a channel.
charset - Variable in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
charset - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
charset - Variable in class org.glassfish.grizzly.utils.StringEncoder
 
Charsets - Class in org.glassfish.grizzly.utils
Charset utility class.
Charsets() - Constructor for class org.glassfish.grizzly.utils.Charsets
 
check() - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
check() - Method in class org.glassfish.grizzly.streams.StreamDecodeCondition
 
check() - Method in class org.glassfish.grizzly.streams.TransformerInput.TransformerCondition
 
check() - Method in interface org.glassfish.grizzly.utils.conditions.Condition
 
checkConnectFailed(Throwable) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called in order to check if failure happened before Connection was reported as connected.
checkDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
checkDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
checkEmptyRead(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
checkEOL(HttpCodecFilter.HeaderParsingState, Buffer) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
checkEOL(HttpCodecFilter.HeaderParsingState, byte[], int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
checkForEquivalents(List<String>) - Static method in class org.glassfish.tyrus.core.uri.Match
Check for equivalent path.
checkMimeType(String) - Method in class org.glassfish.grizzly.http.CompressionConfig
Returns true if the resource with the given content-type could be compressed, or false otherwise.
checkNormalize(CharChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Check that the URI is normalized following character decoding.
checkNotNull(T, String) - Static method in class org.glassfish.tyrus.core.Utils
Check for null.
checkOrigin(String) - Method in class javax.websocket.server.ServerEndpointConfig.Configurator
Check the value of the Origin header (See Origin Header) the client passed during the opening handshake.
checkOverflow(String) - Method in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
checkpoint - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
checkpoint2 - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
checkRecycled() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
checkUserAgent(HttpRequestPacket) - Method in class org.glassfish.grizzly.http.CompressionConfig
Returns true if based on this configuration user-agent, specified in the HttpRequestPacket, can receive compressed data.
Chunk - Interface in org.glassfish.grizzly.http.util
General interface for CharChunk and BufferChunk.
chunkContentStart - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
chunked - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
chunked(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set true, if this HttpPacket content will be transferred in chunking mode, or false if case of fixed-length message.
CHUNKED - Static variable in class org.glassfish.grizzly.http.server.Constants
 
CHUNKED_ENCODING - Static variable in class org.glassfish.grizzly.http.util.Constants
 
CHUNKED_FILTER - Static variable in class org.glassfish.grizzly.http.server.Constants
Chunked filters (input and output).
ChunkedTransferEncoding - Class in org.glassfish.grizzly.http
Chunked transfer encoding implementation.
ChunkedTransferEncoding(int) - Constructor for class org.glassfish.grizzly.http.ChunkedTransferEncoding
 
chunkingEnabled - Variable in class org.glassfish.grizzly.http.HttpCodecFilter
 
ChunkingFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible to break the incoming/outgoing data into chunks and pass them down/up by the FilterChain.
ChunkingFilter(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter
Construct a ChunkFilter, which will break incoming/outgoing data into chunks of the specified size.
ChunkingFilter.ChunkingDecoder - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingDecoder(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingDecoder
 
ChunkingFilter.ChunkingEncoder - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingEncoder(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingEncoder
 
ChunkingFilter.ChunkingTransformer - Class in org.glassfish.grizzly.utils
 
ChunkingFilter.ChunkingTransformer(int) - Constructor for class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
chunkLength - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
chunkRemainder - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
CIPHER_SUITE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we store the name of the cipher suite being used on an SSL connection (as an object of type java.lang.String).
CIPHER_SUITE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the cipher suite.
CLASS_CHECKER_ADD_MESSAGE_HANDLER_ERROR(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Class {0}.
CLASS_CHECKER_FORBIDDEN_RETURN_TYPE(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: has got unsupported return type.
CLASS_CHECKER_FORBIDDEN_WEB_SOCKET_CLOSE_PARAM(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: @OnClose has got different params than Session or CloseReason.
CLASS_CHECKER_FORBIDDEN_WEB_SOCKET_ERROR_PARAM(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: {2} is not allowed as parameter type for method annotated with @OnError.
CLASS_CHECKER_FORBIDDEN_WEB_SOCKET_OPEN_PARAM(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: {2} has got multiple parameters of identical type.
CLASS_CHECKER_MANDATORY_PARAM_MISSING(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: does not have mandatory Throwable param.
CLASS_CHECKER_MULTIPLE_IDENTICAL_PARAMS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: has got multiple parameters of identical type.
CLASS_LOADER_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which we store the class loader used for loading servlets (as an object of type java.lang.ClassLoader).
CLASS_NOT_INSTANTIATED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Class {0} couldn''t be instantiated.
CLASS_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which we store the class path for our application class loader (as an object of type String), delimited with the appropriate path delimiter for this platform.
classForName(String) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the Class from the class name.
classForName(String, ClassLoader) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the Class from the class name.
classForNameWithException(String) - Method in class org.glassfish.tyrus.core.OsgiRegistry
Get the Class from the class name.
classForNameWithException(String) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the Class from the class name.
classForNameWithException(String, ClassLoader) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the Class from the class name.
ClassLoaderUtil - Class in org.glassfish.grizzly.http.server.util
Simple ClassLoader utility.
ClassLoaderUtil() - Constructor for class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
 
clazz - Variable in class org.glassfish.grizzly.memory.AbstractBufferArray
 
clear() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Clear all the attributes.
clear() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Clear all the attributes.
clear() - Method in interface org.glassfish.grizzly.Buffer
Clears this buffer.
clear() - Method in class org.glassfish.grizzly.ChainProcessorSelector
clear() - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
clear() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
clear() - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Remove all mappings from this map.
clear() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Clears all header fields.
clear() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
clear() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
clear() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
clear() - Method in class org.glassfish.grizzly.utils.ArraySet
Remove all the set elements.
clear() - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
clear() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
clearCookies() - Method in class org.glassfish.grizzly.http.server.Request
Clear the collection of Cookies associated with this Request.
clearHeaders() - Method in class org.glassfish.grizzly.http.server.Request
Clear the collection of Headers associated with this Request.
clearLocales() - Method in class org.glassfish.grizzly.http.server.Request
Clear the collection of Locales associated with this Request.
clearParameters() - Method in class org.glassfish.grizzly.http.server.Request
Clear the collection of parameters associated with this Request.
clearProbes() - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Removes all the monitoring probes, which are registered on the object.
clearProbes() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Removes all the monitoring probes, which are registered on the object.
clearResponse(Connection) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
client() - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the client-side cookies builder.
client(boolean) - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the client-side cookies builder with the specific "strict cookie version compliance".
client(boolean, boolean) - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the client-side cookies builder with the specific "strict cookie version compliance".
ClientContainer - Interface in org.glassfish.tyrus.spi
Entry point for client implementation.
ClientEndpoint - Annotation Type in javax.websocket
The ClientEndpoint annotation a class level annotation is used to denote that a POJO is a web socket client and can be deployed as such.
ClientEndpointConfig - Interface in javax.websocket
The ClientEndpointConfig is a special kind of endpoint configuration object that contains web socket configuration information specific only to client endpoints.
ClientEndpointConfig.Builder - Class in javax.websocket
The ClientEndpointConfig.Builder is a class used for creating ClientEndpointConfig objects for the purposes of deploying a client endpoint.
ClientEndpointConfig.Configurator - Class in javax.websocket
The Configurator class may be extended by developers who want to provide custom configuration algorithms, such as intercepting the opening handshake, or providing arbitrary methods and algorithms that can be accessed from each endpoint instance configured with this configurator.
ClientEndpointConfig.Configurator() - Constructor for class javax.websocket.ClientEndpointConfig.Configurator
 
ClientEngine - Interface in org.glassfish.tyrus.spi
Facade for handling client operations from containers.
ClientEngine.TimeoutHandler - Interface in org.glassfish.tyrus.spi
Indicates to container that handshake timeout was reached.
ClientManager - Class in org.glassfish.tyrus.client
ClientManager implementation.
ClientManager() - Constructor for class org.glassfish.tyrus.client.ClientManager
Create new ClientManager instance.
ClientManager.ReconnectHandler - Class in org.glassfish.tyrus.client
Reconnect handler.
ClientManager.ReconnectHandler() - Constructor for class org.glassfish.tyrus.client.ClientManager.ReconnectHandler
 
clientMode - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Client mode when handshaking.
clientSocketSoTimeout - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
clone(Connection, E) - Method in interface org.glassfish.grizzly.asyncqueue.MessageCloner
Method will be called by AsyncQueueWriter, when message could not be written directly, and will be added to the queue.
clone() - Method in class org.glassfish.grizzly.http.Cookie
Overrides the standard java.lang.Object.clone method to return a copy of this cookie.
cloneBuffer(Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Clones the source Buffer.
cloneBuffer(Buffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Clones the source Buffer.
close() - Method in interface javax.websocket.Session
Close the current conversation with a normal status code and no reason phrase.
close(CloseReason) - Method in interface javax.websocket.Session
Close the current conversation, giving a reason for the closure.
close() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Close AsyncQueueProcessor and release associated resources
close() - Method in interface org.glassfish.grizzly.Closeable
Closes this stream and releases any system resources associated with it.
close(CompletionHandler<Closeable>) - Method in interface org.glassfish.grizzly.Closeable
Closes this stream and releases any system resources associated with it.
close() - Method in interface org.glassfish.grizzly.Connection
Close the Connection
close(CompletionHandler<Closeable>) - Method in interface org.glassfish.grizzly.Connection
Close the Connection
close() - Method in class org.glassfish.grizzly.http.HttpContext
 
close() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
close() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
CLOSE - Static variable in class org.glassfish.grizzly.http.server.Constants
 
close() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Close AsyncQueueProcessor and release associated resources
close() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Close AsyncQueueProcessor and release associated resources
close() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close(CompletionHandler<Closeable>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
close(CompletionHandler<Closeable>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
close() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Closes the StreamReader and causes all subsequent method calls on this object to throw IllegalStateException.
close() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
close() - Method in interface org.glassfish.grizzly.streams.Input
 
close(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Output
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.streams.StreamInput
 
close(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
close(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Close the StreamWriter and make sure all data was flushed.
close() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
close() - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
close(String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Close remote session.
close(String, CloseReason) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Close remote session with custom CloseReason.
close() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
close(CloseReason) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
close(int, String) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
close(CloseReason) - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
close() - Method in class org.glassfish.tyrus.core.TyrusSession
 
close(CloseReason) - Method in class org.glassfish.tyrus.core.TyrusSession
Closes the underlying connection this session is based upon.
close() - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Closes this TyrusWebSocket.
close(int, String) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Closes this TyrusWebSocket using the specified status code and reason.
close(CloseReason) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Closes this TyrusWebSocket using the CloseReason.
close(CloseReason) - Method in interface org.glassfish.tyrus.spi.Connection
Notifies tyrus that underlying transport is closing the connection.
close(CloseReason) - Method in interface org.glassfish.tyrus.spi.Connection.CloseListener
Tyrus notifies that logical connection is closed.
close0(CompletionHandler<Closeable>, CloseReason) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
close0(CompletionHandler<Closeable>, CloseReason) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
CLOSE_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
Closeable - Interface in org.glassfish.grizzly
General asynchronous closable interface.
closeConnection(Connection) - Method in class org.glassfish.grizzly.AbstractTransport
Close the connection, managed by Transport
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
closeConnection(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
CloseFrame - Class in org.glassfish.tyrus.core.frame
Close frame representation.
CloseFrame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.CloseFrame
Constructor.
CloseFrame(CloseReason) - Constructor for class org.glassfish.tyrus.core.frame.CloseFrame
Constructor.
CloseListener<T extends Closeable,C extends ICloseType> - Interface in org.glassfish.grizzly
The listener, which is used to be notified, when Connection gets closed.
CloseReason - Class in javax.websocket
A class encapsulating the reason why a web socket has been closed, or why it is being asked to close.
CloseReason(CloseReason.CloseCode, String) - Constructor for class javax.websocket.CloseReason
Creates a reason for closing a web socket connection with the given code and reason phrase.
CloseReason - Class in org.glassfish.grizzly
An object, describing the reason why Connection was closed.
CloseReason(CloseType, IOException) - Constructor for class org.glassfish.grizzly.CloseReason
 
CloseReason.CloseCode - Interface in javax.websocket
A marker interface for the close codes.
CloseReason.CloseCodes - Enum in javax.websocket
An Enumeration of status codes for a web socket close that are defined in the specification.
closeReasonAtomic - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
CloseReasons - Enum in org.glassfish.tyrus.core
Enum containing standard CloseReasons defined in RFC 6455, see chapter 7.4.1 Defined Status Codes.
closeSilently() - Method in interface org.glassfish.grizzly.Connection
Close the Connection silently, no notification required on completion or failure.
closeSilently() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
CloseType - Enum in org.glassfish.grizzly
 
closeWithReason(CloseReason) - Method in interface org.glassfish.grizzly.Connection
Closes the Connection and provides the reason description.
closeWithReason(CloseReason) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
CLStaticHttpHandler - Class in org.glassfish.grizzly.http.server
HttpHandler, which processes requests to a static resources resolved by a given ClassLoader.
CLStaticHttpHandler(ClassLoader, String...) - Constructor for class org.glassfish.grizzly.http.server.CLStaticHttpHandler
Create HttpHandler, which will handle requests to the static resources resolved by the given class loader.
CLUSTER_CONNECTION_ID_HEADER - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
CLUSTER_CONTEXT - Static variable in class org.glassfish.tyrus.core.cluster.ClusterContext
ClusterContext registration property.
ClusterContext - Class in org.glassfish.tyrus.core.cluster
Cluster related context.
ClusterContext() - Constructor for class org.glassfish.tyrus.core.cluster.ClusterContext
 
ClusterSession - Class in org.glassfish.tyrus.core.cluster
Cluster session represents session present on another node.
ClusterSession(String, ClusterContext, Map<ClusterSession.DistributedMapKey, Object>, TyrusEndpointWrapper, Session) - Constructor for class org.glassfish.tyrus.core.cluster.ClusterSession
Constructor.
ClusterSession.DistributedMapKey - Enum in org.glassfish.tyrus.core.cluster
 
code(LZMADecoder.LZMAInputState, long) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
code(LZMAEncoder.LZMAOutputState, long, long) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
Codec<K,L> - Interface in org.glassfish.grizzly
Codec is able to transform the original message to a custom represantation and vise versa.
CodecFilter<K,L> - Interface in org.glassfish.grizzly.filterchain
 
codecFilter - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
CODECS_CACHE_SIZE - Static variable in class org.glassfish.grizzly.utils.Charsets
 
codeOneBlock(long[], long[], boolean[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
CoderAdapter - Class in org.glassfish.tyrus.core.coder
Adapter for Encoder and Decoder which implements lifecycle methods.
CoderAdapter() - Constructor for class org.glassfish.tyrus.core.coder.CoderAdapter
 
CoderWrapper<T> - Class in org.glassfish.tyrus.core.coder
Wrapper of coders storing the coder coder class (and optionally coder instance), return type of the encode / decode method and coder class.
CoderWrapper(Class<? extends T>, Class<?>) - Constructor for class org.glassfish.tyrus.core.coder.CoderWrapper
Construct new coder wrapper.
CoderWrapper(T, Class<?>) - Constructor for class org.glassfish.tyrus.core.coder.CoderWrapper
Construct new coder wrapper.
COLON - Static variable in class org.glassfish.grizzly.http.server.Constants
COLON.
COLON - Static variable in class org.glassfish.grizzly.http.util.Constants
COLON.
COLON_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
COMMA - Static variable in class org.glassfish.grizzly.http.util.Constants
COMMA.
comment - Variable in class org.glassfish.grizzly.http.Cookie
 
compact() - Method in interface org.glassfish.grizzly.Buffer
Compacts this buffer  (optional operation).
compact() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
compact() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
compact() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
COMPARATOR - Static variable in class org.glassfish.tyrus.core.uri.internal.PathPattern
Path pattern comparator that defers to comparing the templates associated with the patterns.
COMPARATOR - Static variable in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Order the templates according to JAX-RS specification.
compare(int, int, String) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
compare(ByteChunk, byte[]) - Static method in class org.glassfish.grizzly.http.util.StringCache
Compare given byte chunk with byte array.
compare(CharChunk, char[]) - Static method in class org.glassfish.grizzly.http.util.StringCache
Compare given char chunk with char array.
compareAndSetCurrentElement(E, E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
compareIgnoreCase(int, int, String) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
compareTo(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
compareTo(String) - Method in class org.glassfish.grizzly.utils.JdkVersion
 
compareTo(JdkVersion) - Method in class org.glassfish.grizzly.utils.JdkVersion
 
complete(ProcessorResult) - Method in class org.glassfish.grizzly.Context
 
COMPLETE_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
completeAndRecycle() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
completed(E) - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was completed.
completed(E) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was completed.
COMPLETED - Static variable in interface org.glassfish.grizzly.Interceptor
 
completed(RegisterChannelResult) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
completed(RegisterChannelResult) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.RegisterChannelCompletionHandler
 
completed(Object) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
completed(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
completed(E) - Method in class org.glassfish.tyrus.spi.CompletionHandler
The operation was completed.
completionHandler - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
CompletionHandler<E> - Interface in org.glassfish.grizzly
Interface, which will be used by Grizzly to notify about asynchronous I/O operations status updates.
completionHandler - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
CompletionHandler<E> - Class in org.glassfish.tyrus.spi
A callback to notify about asynchronous I/O operations status updates.
CompletionHandler() - Constructor for class org.glassfish.tyrus.spi.CompletionHandler
 
CompletionHandlerAdapter<A,B> - Class in org.glassfish.grizzly.utils
 
CompletionHandlerAdapter(FutureImpl<A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
CompletionHandlerAdapter(FutureImpl<A>, CompletionHandler<A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
CompletionHandlerAdapter(FutureImpl<A>, CompletionHandler<A>, GenericAdapter<B, A>) - Constructor for class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
completionHandlers - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
COMPONENT_PROVIDER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Component provider for class {0} not found.
COMPONENT_PROVIDER_THREW_EXCEPTION(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Component provider threw exception when providing instance of class {0}.
ComponentProvider - Class in org.glassfish.tyrus.core
Provides an instance.
ComponentProvider() - Constructor for class org.glassfish.tyrus.core.ComponentProvider
 
ComponentProviderService - Class in org.glassfish.tyrus.core
Provides an instance of component.
ComponentProviderService(ComponentProviderService) - Constructor for class org.glassfish.tyrus.core.ComponentProviderService
Copy constructor.
compose(byte[], String) - Static method in class org.glassfish.grizzly.http.util.ContentType
Composes a content-type array, based on the mime-type represented by a byte array and a charset attribute value, represented by a String.
composeComprehensiveException() - Method in class org.glassfish.tyrus.core.ErrorCollector
Create DeploymentException with message concatenated from collected exceptions.
composeContentType(String, String) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
 
CompositeBuffer - Class in org.glassfish.grizzly.memory
 
CompositeBuffer() - Constructor for class org.glassfish.grizzly.memory.CompositeBuffer
 
compositeBuffer - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
CompositeBuffer.BulkOperation - Interface in org.glassfish.grizzly.memory
Bulk Buffer operation, responsible for byte-by-byte Buffer processing.
CompositeBuffer.DisposeOrder - Enum in org.glassfish.grizzly.memory
The order in which internal Buffers will be disposed.
CompositeBuffer.Setter - Interface in org.glassfish.grizzly.memory
Setter.
compressFile(FileCacheEntry) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Creates a temporary compressed representation of the given cache entry.
CompressionConfig - Class in org.glassfish.grizzly.http
Compression configuration class.
CompressionConfig() - Constructor for class org.glassfish.grizzly.http.CompressionConfig
 
CompressionConfig(CompressionConfig) - Constructor for class org.glassfish.grizzly.http.CompressionConfig
The copy constructor.
CompressionConfig(CompressionConfig.CompressionMode, int, Set<String>, Set<String>) - Constructor for class org.glassfish.grizzly.http.CompressionConfig
 
CompressionConfig.CompressionMode - Enum in org.glassfish.grizzly.http
 
CompressionConfig.CompressionModeI - Interface in org.glassfish.grizzly.http
Common CompressionMode interface.
CompressionEncodingFilter - Class in org.glassfish.grizzly.http.server
 
CompressionEncodingFilter(CompressionConfig, String[]) - Constructor for class org.glassfish.grizzly.http.server.CompressionEncodingFilter
 
CompressionEncodingFilter(CompressionConfig.CompressionModeI, int, String[], String[], String[]) - Constructor for class org.glassfish.grizzly.http.server.CompressionEncodingFilter
 
CompressionLevel - Enum in org.glassfish.grizzly.http.server
Deprecated.
pls. use org.glassfish.grizzly.http.Compression#CompressionLevel.
concreteClass - Variable in class org.glassfish.tyrus.core.ReflectionHelper.DeclaringClassInterfacePair
 
condition - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
Condition - Interface in org.glassfish.grizzly.utils.conditions
 
config - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
config - Variable in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
configSelectorPool(ThreadPoolConfig) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Configure the SelectorRunner pool's default core and max pool size.
configurator(ClientEndpointConfig.Configurator) - Method in class javax.websocket.ClientEndpointConfig.Builder
Sets the configurator object for the configuration this builder will build.
configurator(ServerEndpointConfig.Configurator) - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Sets the custom configurator to use on the configuration object built by this builder.
configure(SSLEngine) - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
configure(SSLEngine) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Configure passed SSLEngine, using current configurator settings
configureBlocking(boolean) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the Transport mode.
configureBlocking(boolean) - Method in interface org.glassfish.grizzly.Connection
Sets the Connection mode.
configureBlocking(boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
configureBlocking(boolean) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
configureBlocking(boolean) - Method in interface org.glassfish.grizzly.Transport
Sets the Transport mode.
configureCompressionEncodings(NetworkListener) - Method in class org.glassfish.grizzly.http.server.HttpServer
 
configureNIOConnection(NIOConnection) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
configureSessionCookie(Cookie) - Method in class org.glassfish.grizzly.http.server.Request
Configures the given JSESSIONID cookie.
configureStandalone(boolean) - Method in interface org.glassfish.grizzly.Connection
Deprecated.
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
configureStandalone(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
configureStandalone(boolean) - Method in interface org.glassfish.grizzly.Transport
 
CONFLICT_409 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
CONINTUE_100 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
connect(String, int) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connect(E) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes and establishes Connection to the specific remoteAddress.
connect(E, CompletionHandler<Connection>) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes and establishes Connection to the specific remoteAddress.
connect(E, E) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes Connection, binds it to the specific local and remote remoteAddress.
connect(E, E, CompletionHandler<Connection>) - Method in interface org.glassfish.grizzly.ConnectorHandler
Creates, initializes Connection, binds it to the specific local and remote remoteAddress.
CONNECT - Static variable in class org.glassfish.grizzly.http.Method
 
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connect(String, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connect(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
Creates non-connected UDP Connection.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connect() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates non-connected UDP Connection.
connect(String, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connect(SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes and connects socket to the specific SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Creates, initializes socket, binds it to the specific local and remote SocketAddress and returns Connection, representing socket.
connect(String, int) - Method in interface org.glassfish.grizzly.SocketConnectorHandler
Creates, initializes and connects socket to the specific remote host and port and returns Connection, representing socket.
connect() - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientSocket
Connects to the given URI.
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectAsync(SocketAddress, SocketAddress, CompletionHandler<Connection>, boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connectCloseSemaphor - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
connected() - Method in interface org.glassfish.grizzly.nio.transport.TCPNIOConnection.ConnectResultHandler
 
connection - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
Connection<L> - Interface in org.glassfish.grizzly
Common interface, which represents any kind of connection.
CONNECTION - Static variable in class org.glassfish.grizzly.http.server.Constants
 
connection - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
Connection - Interface in org.glassfish.tyrus.spi
A logical websocket connection.
CONNECTION - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
Connection.CloseListener - Interface in org.glassfish.grizzly
Deprecated.
Connection.CloseListener - Interface in org.glassfish.tyrus.spi
Transport close listener that receives connection close notifications from Tyrus.
Connection.CloseType - Enum in org.glassfish.grizzly
Deprecated.
CONNECTION_HAS_BEEN_CLOSED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
The connection has been closed.
CONNECTION_NULL() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Connection is null.
connectionMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Connection probes
connectionProbe - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
ConnectionProbe - Interface in org.glassfish.grizzly
Monitoring probe providing callbacks that may be invoked by Grizzly Connection implementations.
ConnectionProbe.Adapter - Class in org.glassfish.grizzly
ConnectionProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
ConnectionProbe.Adapter() - Constructor for class org.glassfish.grizzly.ConnectionProbe.Adapter
 
connectionTimeout - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
connectionTimeoutMillis - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectionTimeoutMillis - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
ConnectorHandler<E> - Interface in org.glassfish.grizzly
Client side connector handler API.
connectSync(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
connectSync(SocketAddress, SocketAddress, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
connectToServer(Object, URI) - Method in interface javax.websocket.WebSocketContainer
Connect the supplied annotated endpoint instance to its server.
connectToServer(Class<?>, URI) - Method in interface javax.websocket.WebSocketContainer
Connect the supplied annotated endpoint to its server.
connectToServer(Endpoint, ClientEndpointConfig, URI) - Method in interface javax.websocket.WebSocketContainer
Connect the supplied programmatic client endpoint instance to its server with the given configuration.
connectToServer(Class<? extends Endpoint>, ClientEndpointConfig, URI) - Method in interface javax.websocket.WebSocketContainer
Connect the supplied programmatic endpoint to its server with the given configuration.
connectToServer(Class, URI) - Method in class org.glassfish.tyrus.client.ClientManager
 
connectToServer(Class<? extends Endpoint>, ClientEndpointConfig, URI) - Method in class org.glassfish.tyrus.client.ClientManager
 
connectToServer(Endpoint, ClientEndpointConfig, URI) - Method in class org.glassfish.tyrus.client.ClientManager
 
connectToServer(Object, URI) - Method in class org.glassfish.tyrus.client.ClientManager
 
Constants - Class in org.glassfish.grizzly.http.server
Constants.
Constants() - Constructor for class org.glassfish.grizzly.http.server.Constants
 
Constants - Class in org.glassfish.grizzly.http.util
Constants.
Constants() - Constructor for class org.glassfish.grizzly.http.util.Constants
 
ContainerProvider - Class in javax.websocket
Provider class that allows the developer to get a reference to the implementation of the WebSocketContainer.
ContainerProvider() - Constructor for class javax.websocket.ContainerProvider
 
contains(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
contains(E) - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
contains(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
contains(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
contains(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
contains(String) - Static method in class org.glassfish.grizzly.http.util.MimeType
 
contains(Object) - Method in class org.glassfish.grizzly.utils.ArraySet
contains(Object) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Returns true if this queue contains the specified element.
contains(Charset) - Method in class org.glassfish.tyrus.core.StrictUtf8
 
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
containsAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
containsCTL(String, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
containsHeader(String) - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if the mime header with the specific name is present among the HttpHeader mime headers, or false otherwise.
containsHeader(Header) - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if the mime Header is present among the HttpHeader mime headers, otherwise returns false.
containsHeader(String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Returns true, if the mime header with the specific name is present among the HttpHeader mime headers, or false otherwise.
containsHeader(Header) - Method in class org.glassfish.grizzly.http.HttpTrailer
Returns true, if the mime Header is present among the HttpHeader mime headers, otherwise returns false.
containsHeader(String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Returns true, if the mime header with the specific name is present among the HttpHeader mime headers, or false otherwise.
containsHeader(Header) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Returns true, if the mime Header is present among the HttpHeader mime headers, otherwise returns false.
containsHeader(String) - Method in class org.glassfish.grizzly.http.server.Response
Has the specified header been set already in this response?
containsHeader(Header) - Method in class org.glassfish.grizzly.http.server.Response
Has the specified header been set already in this response?
containsKey(Object) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
containsValue(Object) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
content - Variable in class org.glassfish.grizzly.http.HttpContent.Builder
 
content(Buffer) - Method in class org.glassfish.grizzly.http.HttpContent.Builder
Set the HttpContent chunk content Buffer.
content - Variable in class org.glassfish.grizzly.http.HttpContent
 
ContentEncoding - Interface in org.glassfish.grizzly.http
Abstraction, which represents HTTP content-encoding.
ContentEncodingException - Exception in org.glassfish.grizzly.http
 
ContentEncodingException() - Constructor for exception org.glassfish.grizzly.http.ContentEncodingException
 
ContentEncodingException(String) - Constructor for exception org.glassfish.grizzly.http.ContentEncodingException
 
ContentEncodingException(Throwable) - Constructor for exception org.glassfish.grizzly.http.ContentEncodingException
 
ContentEncodingException(String, Throwable) - Constructor for exception org.glassfish.grizzly.http.ContentEncodingException
 
contentEncodings - Variable in class org.glassfish.grizzly.http.HttpCodecFilter
 
contentLength - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
contentLength(long) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set the content-length of this HttpPacket.
contentLength - Variable in class org.glassfish.grizzly.http.HttpHeader
 
contentLengthHeadersCount - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
contentLengthsDiffer - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
contentType - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
contentType(String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set the content-type of this HttpPacket.
contentType - Variable in class org.glassfish.grizzly.http.HttpHeader
 
contentType - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
ContentType - Class in org.glassfish.grizzly.http.util
This class serves as a Content-Type holder, plus it implements useful utility methods to work with content-type.
ContentType.SettableContentType - Class in org.glassfish.grizzly.http.util
Mutable ContentType object.
Context - Class in org.glassfish.grizzly
Object, which is responsible for holding context during I/O event processing.
Context() - Constructor for class org.glassfish.grizzly.Context
 
context - Variable in class org.glassfish.grizzly.http.server.util.Mapper
Context associated with this wrapper, used for wrapper mapping.
context - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
Context.MinimalisticArrayList<E> - Class in org.glassfish.grizzly
 
contextList - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Host
 
contextPath - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
contexts - Variable in class org.glassfish.grizzly.http.server.util.Mapper.ContextList
 
contextualEncode(String, UriComponent.Type) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Contextually encodes the characters of string that are either non-ASCII characters or are ASCII characters that must be percent-encoded using the UTF-8 encoding.
contextualEncode(String, UriComponent.Type, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Contextually encodes the characters of string that are either non-ASCII characters or are ASCII characters that must be percent-encoded using the UTF-8 encoding.
CONTROL_FRAME_FRAGMENTED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Fragmented control frame.
CONTROL_FRAME_LENGTH() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Control frame payloads must be no greater than 125 bytes.
convert(ByteChunk, CharChunk) - Method in class org.glassfish.grizzly.http.util.B2CConverter
Convert a buffer of bytes into a chars
convert(ByteChunk, CharChunk, int) - Method in class org.glassfish.grizzly.http.util.B2CConverter
 
convert(ByteChunk, CharChunk) - Method in class org.glassfish.grizzly.http.util.B2CConverterBlocking
Deprecated. 
convert(ByteChunk, CharChunk, int) - Method in class org.glassfish.grizzly.http.util.B2CConverterBlocking
 
convert(char[], int, int) - Method in class org.glassfish.grizzly.http.util.C2BConverter
Generate the bytes using the specified encoding
convert(String) - Method in class org.glassfish.grizzly.http.util.C2BConverter
Generate the bytes using the specified encoding
convert(String, int, int) - Method in class org.glassfish.grizzly.http.util.C2BConverter
Generate the bytes using the specified encoding
convert(char) - Method in class org.glassfish.grizzly.http.util.C2BConverter
Generate the bytes using the specified encoding
convert(MessageBytes) - Method in class org.glassfish.grizzly.http.util.C2BConverter
Convert a message bytes chars to bytes
convert(String) - Static method in class org.glassfish.grizzly.http.util.HexUtils
Convert a String of hexadecimal digits into the corresponding byte array by encoding each two hexadecimal digits as a byte.
convert(byte[]) - Static method in class org.glassfish.grizzly.http.util.HexUtils
Convert a byte array into a printable format containing a String of hexadecimal digit characters (two per byte).
convert(ByteChunk) - Method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode, will modify the source.
convert(ByteChunk, boolean) - Method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode the ByteChunk
convert(ByteChunk, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode the ByteChunk
convert(CharChunk) - Method in class org.glassfish.grizzly.http.util.UDecoder
In-buffer processing - the buffer will be modified Includes converting '+' to ' '.
convert(CharChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.UDecoder
In-buffer processing - the buffer will be modified
convert(MessageBytes) - Method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode, will modify the source Includes converting '+' to ' '.
convert(MessageBytes, boolean) - Method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode, will modify the source
convert(MessageBytes, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.UDecoder
URLDecode, will modify the source
convert(String) - Static method in class org.glassfish.grizzly.http.util.UDecoder
 
convert(String, boolean) - Static method in class org.glassfish.grizzly.http.util.UDecoder
 
convert(ByteChunk, CharChunk) - Method in class org.glassfish.grizzly.http.util.UTF8Decoder
 
convert(Buffer, int, char[], int, int) - Method in class org.glassfish.grizzly.http.util.UTF8Decoder
Converts the Buffer to char[] using UTF8 encoding.
convert(byte[], int, char[], int, int) - Method in class org.glassfish.grizzly.http.util.UTF8Decoder
Converts the Buffer to char[] using UTF8 encoding.
convert2Int(byte[]) - Static method in class org.glassfish.grizzly.http.util.HexUtils
Convert 4 hex digits to an int, and return the number of converted bytes.
convertASCII(MessageBytes) - Static method in class org.glassfish.grizzly.http.util.B2CConverter
Character conversion of a US-ASCII MessageBytes.
convertASCII(MessageBytes) - Static method in class org.glassfish.grizzly.http.util.B2CConverterBlocking
Character conversion of a US-ASCII MessageBytes.
convertMB(MessageBytes) - Method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Character conversion of the a US-ASCII MessageBytes.
convertQValueToFloat(DataChunk, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
 
convertQValueToFloat(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
 
convertQValueToFloat(String, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
 
convertQValueToFloat(char[], int, int) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
 
convertToBytes(String) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Convert specified String to a byte array.
convertToChars(DataChunk, Charset) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Converts the normalized the HTTP request represented by the bytes inside DataChunk to chars representation, using the passed encoding.
convertToLong(String) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
Cookie - Class in org.glassfish.grizzly.http
Creates a cookie, a small amount of information sent by a servlet to a Web browser, saved by the browser, and later sent back to the server.
Cookie() - Constructor for class org.glassfish.grizzly.http.Cookie
 
Cookie(String, String) - Constructor for class org.glassfish.grizzly.http.Cookie
Constructs a cookie with a specified name and value.
COOKIE_VERSION_ONE_STRICT_COMPLIANCE - Static variable in class org.glassfish.grizzly.http.util.CookieUtils
If set to true, then it will double quote the value and update cookie version when there is special characters.
CookieParserUtils - Class in org.glassfish.grizzly.http.util
The set of Cookie utility methods for cookie parsing.
CookieParserUtils() - Constructor for class org.glassfish.grizzly.http.util.CookieParserUtils
 
Cookies - Class in org.glassfish.grizzly.http
A collection of cookies - reusable and tuned for server side performance.
Cookies() - Constructor for class org.glassfish.grizzly.http.Cookies
 
cookies - Variable in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
cookies - Variable in class org.glassfish.grizzly.http.server.Request
The set of cookies associated with this Request.
CookiesBuilder - Class in org.glassfish.grizzly.http
Cookies builder, which could be used to construct a set of cookies, either client or server.
CookiesBuilder() - Constructor for class org.glassfish.grizzly.http.CookiesBuilder
 
CookiesBuilder.AbstractCookiesBuilder<E extends CookiesBuilder.AbstractCookiesBuilder> - Class in org.glassfish.grizzly.http
 
CookiesBuilder.AbstractCookiesBuilder(boolean, boolean) - Constructor for class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
CookiesBuilder.ClientCookiesBuilder - Class in org.glassfish.grizzly.http
 
CookiesBuilder.ClientCookiesBuilder(boolean, boolean) - Constructor for class org.glassfish.grizzly.http.CookiesBuilder.ClientCookiesBuilder
 
CookiesBuilder.ServerCookiesBuilder - Class in org.glassfish.grizzly.http
 
CookiesBuilder.ServerCookiesBuilder(boolean, boolean) - Constructor for class org.glassfish.grizzly.http.CookiesBuilder.ServerCookiesBuilder
 
CookieSerializerUtils - Class in org.glassfish.grizzly.http.util
The set of Cookie utility methods for cookie serialization.
CookieSerializerUtils() - Constructor for class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
cookiesParsed - Variable in class org.glassfish.grizzly.http.server.Request
Cookies parsed flag.
CookieUtils - Class in org.glassfish.grizzly.http.util
The general set of Cookie utility methods.
CookieUtils() - Constructor for class org.glassfish.grizzly.http.util.CookieUtils
 
copy() - Method in interface org.glassfish.grizzly.Copyable
 
copy() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
copy(File, File) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Copy the specified file or directory to the destination.
copy() - Method in class org.glassfish.grizzly.ReadResult
 
copy() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
copy() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
copy() - Method in class org.glassfish.grizzly.WriteResult
 
COPY_CLONER - Static variable in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
Copyable - Interface in org.glassfish.grizzly
General interface for the objects, that could be copied/cloned.
copyBlock(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
copyBytes(byte[], int, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Copy an array of bytes to a different position.
copyFrom(AttributeHolder) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Copies attributes from the srcAttributes to this AttributeHolder
copyFrom(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
copyFrom(Context.MinimalisticArrayList<E>) - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
copyFrom(MimeHeaders) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
copyTo(AttributeHolder) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Copies attributes from this AttributeHolder to the dstAttributes.
copyTo(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
corePoolSize - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
CR - Static variable in class org.glassfish.grizzly.http.server.Constants
CR.
CR - Static variable in class org.glassfish.grizzly.http.util.Constants
CR.
CRC - Class in org.glassfish.grizzly.compression.lzma.impl
CRC
CRC() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.CRC
 
create() - Static method in class javax.websocket.ClientEndpointConfig.Builder
Creates a new builder object with no subprotocols, extensions, encoders, decoders and a null configurator.
create(Class<?>, String) - Static method in class javax.websocket.server.ServerEndpointConfig.Builder
Creates the builder with the mandatory information of the endpoint class (programmatic or annotated), the relative URI or URI-template to use, and with no subprotocols, extensions, encoders, decoders or custom configurator.
create() - Method in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
create() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
create(Connection, Buffer, CompletionHandler, Interceptor<ReadResult>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
create(Connection, WritableMessage, CompletionHandler, Object, PushBackHandler, boolean) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
create(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
create(int, int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
create(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
create(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
create() - Static method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
create() - Static method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
create(Connection) - Static method in class org.glassfish.grizzly.Context
 
create(Connection, Processor, IOEvent, IOEventLifeCycleListener) - Static method in class org.glassfish.grizzly.Context
 
create(Connection) - Static method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
create() - Method in class org.glassfish.grizzly.http.HttpBrokenContent.Builder
 
create() - Static method in class org.glassfish.grizzly.http.HttpBrokenContent
 
create(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpBrokenContent
 
create() - Method in class org.glassfish.grizzly.http.HttpContent.Builder
 
create() - Static method in class org.glassfish.grizzly.http.HttpContent
 
create(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpContent
 
create(HttpHeader, boolean) - Static method in class org.glassfish.grizzly.http.HttpContent
 
create(HttpHeader, boolean, Buffer) - Static method in class org.glassfish.grizzly.http.HttpContent
 
create() - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
 
create() - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
create() - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
create() - Method in class org.glassfish.grizzly.http.HttpTrailer.Builder
 
create() - Static method in class org.glassfish.grizzly.http.HttpTrailer
 
create(HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpTrailer
 
create(HttpContent, Buffer) - Static method in class org.glassfish.grizzly.http.ParsingResult
 
create(String, String) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
create(HttpRequestPacket) - Static method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
create() - Static method in class org.glassfish.grizzly.http.server.Request
 
create() - Static method in class org.glassfish.grizzly.http.server.SuspendStatus
 
create() - Static method in class org.glassfish.grizzly.http.server.util.SimpleDateFormats
 
create() - Static method in class org.glassfish.grizzly.http.util.CacheableDataChunk
 
create() - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct cancelled Future.
create(R) - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct Future with the result.
create(Throwable) - Static method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Construct failed Future.
create() - Static method in class org.glassfish.grizzly.impl.SafeFutureImpl
Construct SafeFutureImpl.
create() - Static method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Construct Future.
create() - Static method in class org.glassfish.grizzly.memory.BufferArray
 
create() - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
Construct BuffersBuffer.
create(MemoryManager) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create(MemoryManager, Buffer...) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create(MemoryManager, Buffer[], boolean) - Static method in class org.glassfish.grizzly.memory.BuffersBuffer
 
create() - Static method in class org.glassfish.grizzly.memory.ByteBufferArray
 
create(NIOTransport) - Static method in class org.glassfish.grizzly.nio.SelectorRunner
 
create() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler.Builder
 
create() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
create() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
create() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler.Builder
 
create() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
create() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
create() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
create(Connection<L>) - Static method in class org.glassfish.grizzly.ReadResult
 
create(Connection<L>, K, L, int) - Static method in class org.glassfish.grizzly.ReadResult
 
create(Connection<L>) - Static method in class org.glassfish.grizzly.WriteResult
 
create(Connection<L>, K, L, long) - Static method in class org.glassfish.grizzly.WriteResult
 
create(Class<T>) - Method in class org.glassfish.tyrus.core.ComponentProvider
Create new instance.
create() - Static method in class org.glassfish.tyrus.core.ComponentProviderService
Create new instance of ComponentProviderService.
create(Class<T>) - Method in class org.glassfish.tyrus.core.DefaultComponentProvider
 
create() - Static method in class org.glassfish.tyrus.core.RequestContext.Builder
Create empty builder.
createAddrHolder(L) - Method in class org.glassfish.grizzly.WriteResult
Create an address holder.
createAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name
createAttribute(String, T) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name and default value
createAttribute(String, NullaryFunction<T>) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Create Attribute with name and initializer, which will be called, if Attribute's value is null on a AttributedObject
createAttribute(String, NullaryFunction<T>) - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
createAttribute(String) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name
createAttribute(String, T) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name and default value
createAttribute(String, NullaryFunction<T>) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
Create Attribute with name and initializer, which will be called, if Attribute's value is null on a AttributedObject
createAttribute(String, NullaryFunction<T>) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
createClassIterator(Class<T>, String, ClassLoader, boolean) - Method in class org.glassfish.tyrus.core.ServiceFinder.DefaultServiceIteratorProvider
 
createClassIterator(Class<T>, String, ClassLoader, boolean) - Method in class org.glassfish.tyrus.core.ServiceFinder.ServiceIteratorProvider
Iterate over provider classes of a service.
createClassloader(File, ClassLoader) - Static method in class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
Deprecated.
removal candidate, never used
createClient() - Static method in class org.glassfish.tyrus.client.ClientManager
Create new ClientManager instance.
createClient(WebSocketContainer) - Static method in class org.glassfish.tyrus.client.ClientManager
Create new ClientManager instance on top of provided WebSocketContainer instance.
createClient(String) - Static method in class org.glassfish.tyrus.client.ClientManager
Create new ClientManager instance.
createClient(String, WebSocketContainer) - Static method in class org.glassfish.tyrus.client.ClientManager
Create new ClientManager instance on top of provided WebSocketContainer instance.
createClient() - Static method in class org.glassfish.tyrus.core.ComponentProviderService
Create new instance of ComponentProviderService.
createClientHandshake(UpgradeRequest) - Static method in class org.glassfish.tyrus.core.Handshake
Client-side handshake.
createComplete() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createComplete(Object) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createCompletedResult(O, I) - Static method in class org.glassfish.grizzly.TransformationResult
 
createConnection(Writer, Connection.CloseListener) - Method in interface org.glassfish.tyrus.spi.WebSocketEngine.UpgradeInfo
Creates a connection if the upgrade is successful.
createConnectionId() - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Create connection id.
createContainer(Map<String, Object>) - Method in class org.glassfish.tyrus.spi.ServerContainerFactory
 
createContext(Connection, FilterChainContext.Operation) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
 
CREATED_201 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
createDefaultIdleDelayedExecutor() - Static method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
createDefaultIdleDelayedExecutor(long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
createDefaultIdleDelayedExecutor() - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
createDefaultIdleDelayedExecutor(long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
createDefaultWorkerPoolConfig(Transport) - Method in interface org.glassfish.grizzly.strategies.WorkerThreadPoolConfigProducer
 
createDelayQueue(DelayedExecutor.Worker<E>, DelayedExecutor.Resolver<E>) - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
createError() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createError(Object) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createErrorResult(int, String) - Static method in class org.glassfish.grizzly.TransformationResult
 
createFlushEvent() - Static method in class org.glassfish.grizzly.filterchain.TransportFilter
 
createFlushEvent(CompletionHandler) - Static method in class org.glassfish.grizzly.filterchain.TransportFilter
 
createHandler(boolean) - Method in enum org.glassfish.tyrus.core.Version
 
createHeapBuffer(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Create a new HeapBuffer based on the current heap.
createImmutable(AsyncQueueReader<L>, AsyncQueueWriter<L>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
createIncompletedResult(I) - Static method in class org.glassfish.grizzly.TransformationResult
 
createInputStream() - Method in class org.glassfish.grizzly.http.server.Request
Create and return a NIOInputStream to read the content associated with this Request.
createInstance() - Static method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
createInstance(ThreadPoolConfig) - Static method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
createIterator(Class<T>, String, ClassLoader, boolean) - Method in class org.glassfish.tyrus.core.ServiceFinder.DefaultServiceIteratorProvider
 
createIterator(Class<T>, String, ClassLoader, boolean) - Method in class org.glassfish.tyrus.core.ServiceFinder.ServiceIteratorProvider
Iterate over provider instances of a service.
createJmxManagementObject() - Method in class org.glassfish.grizzly.AbstractTransport
Create the Transport JMX management object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.http.KeepAlive
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Create the Memory Manager JMX management object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
createJmxManagementObject() - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
createJmxManagementObject() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Create the Transport JMX management object.
createJmxManagementObject() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Create the Transport JMX management object.
createLeave() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createManagementObject() - Method in interface org.glassfish.grizzly.http.server.jmxbase.Monitorable
Returns a new JMX Object that may be registered with the Grizzly JMX manager.
createManagementObject() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
createManagementObject() - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Create the JMX Object, which represents this object.
createManagementObject() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Create the JMX Object, which represents this object.
createMemoryManager() - Method in interface org.glassfish.grizzly.memory.DefaultMemoryManagerFactory
 
createMutable(AsyncQueueReader<L>, AsyncQueueWriter<L>) - Static method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.Factory
 
createNote(String) - Static method in class org.glassfish.grizzly.http.HttpRequestPacket
Create a named Note associated with this Request.
createNote(String) - Static method in class org.glassfish.grizzly.http.server.Request
Create a named Note associated with this Request.
createNotRun() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createOptimizedTransportFilter(TransportFilter) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
createOutputStream() - Method in class org.glassfish.grizzly.http.server.Response
Create and return a ServletOutputStream to write the content associated with this Response.
createReadyFuture(R) - Static method in class org.glassfish.grizzly.utils.Futures
Create a Future, which has a preset result.
createReadyFuture(Throwable) - Static method in class org.glassfish.grizzly.utils.Futures
Create a Future, which has a preset failure.
createRecord(Connection, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, SocketAddress, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
createReregister(Context) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createRerun(Context) - Static method in class org.glassfish.grizzly.ProcessorResult
 
createSafeAttributeHolder() - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Creates and returns new thread-safe AttributeHolder
createSafeAttributeHolder() - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
createSafeFuture() - Static method in class org.glassfish.grizzly.utils.Futures
Returns thread-safe FutureImpl implementation.
createServerContainer() - Static method in class org.glassfish.tyrus.spi.ServerContainerFactory
 
createServerContainer(Map<String, Object>) - Static method in class org.glassfish.tyrus.spi.ServerContainerFactory
 
createSessionForRemoteEndpoint(TyrusWebSocket, String, List<Extension>) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Creates a Session based on the TyrusWebSocket, subprotocols and extensions.
createSessionId() - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Create session id.
createShutdownExecutorService() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
createSimpleServer() - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String, int) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String, PortRange) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String, SocketAddress) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String, String, int) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSimpleServer(String, String, PortRange) - Static method in class org.glassfish.grizzly.http.server.HttpServer
 
createSmallBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
createSocket(ProtocolHandler) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Factory method to create new TyrusWebSocket instances.
createSSLContext() - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
createSSLEngine() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create and configure SSLEngine, basing on current settings.
createStateObject() - Method in class org.glassfish.grizzly.AbstractTransformer
 
createStateObject() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
createStateObject() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
createStateObject() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
createStateObject() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
createTaskQueue(TaskQueue.MutableMaxQueueSize) - Static method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
createTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
createTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
createTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
createTerminate() - Static method in class org.glassfish.grizzly.ProcessorResult
 
createThreadLocalPool() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
createThreadLocalPool() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
createThreadLocalPool() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPoolProvider
 
createUnsafeAttributeHolder() - Method in interface org.glassfish.grizzly.attributes.AttributeBuilder
Creates and returns new non thread-safe AttributeHolder
createUnsafeAttributeHolder() - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
createUnsafeFuture() - Static method in class org.glassfish.grizzly.utils.Futures
Returns non thread-safe FutureImpl implementation.
createUpgradeRequest(URI, ClientEngine.TimeoutHandler) - Method in class org.glassfish.tyrus.client.TyrusClientEngine
 
createUpgradeRequest(URI, ClientEngine.TimeoutHandler) - Method in interface org.glassfish.tyrus.spi.ClientEngine
Create upgrade request and register ClientEngine.TimeoutHandler.
createURI(Map<String, String>) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Create a URI by substituting any template variables for corresponding template values.
createURI(String...) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Create a URI by substituting any template variables for corresponding template values.
createURI(String[], int, int) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Create a URI by substituting any template variables for corresponding template values.
createURI(String, String, String, String, String, String, String, String, Map<String, ?>, boolean, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a URI from the component parts each of which may contain template variables.
createURI(String, String, String, String, String, String, String, String, Object[], boolean, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a URI from the component parts each of which may contain template variables.
createURIWithStringValues(String, String, String, String, String, String, String, String, Map<String, ?>, boolean, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a URI from the component parts each of which may contain template variables.
createURIWithStringValues(String, String, String, String, String, String, String, String, String[], boolean, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a URI from the component parts each of which may contain template variables.
createURLClassLoader(String) - Static method in class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
Construct a URLClassLoader based on a canonical file location.
createURLClassLoader(String, ClassLoader) - Static method in class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
Construct a URLClassLoader based on a canonical file location.
CRLF - Static variable in class org.glassfish.grizzly.http.server.Constants
CRLF.
CRLF_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
ctx - Variable in class org.glassfish.grizzly.http.server.Request
 
ctx - Variable in class org.glassfish.grizzly.http.server.Response
Grizzly FilterChain context, related to this HTTP request/response
CUSTOM(String) - Static method in class org.glassfish.grizzly.http.Method
 
CUSTOM(String, Method.PayloadExpectation) - Static method in class org.glassfish.grizzly.http.Method
 
customizeErrorResponse(HttpResponsePacket) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 

D

DATA_UNEXPECTED_LENGTH(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Data read ({0}) is not the expected size ({1}).
DataChunk - Class in org.glassfish.grizzly.http.util
Buffer chunk representation.
DataChunk() - Constructor for class org.glassfish.grizzly.http.util.DataChunk
 
DataChunk(ByteChunk, BufferChunk, CharChunk, String) - Constructor for class org.glassfish.grizzly.http.util.DataChunk
 
DataChunk.Type - Enum in org.glassfish.grizzly.http.util
 
DataStructures - Class in org.glassfish.grizzly.utils
 
DataStructures() - Constructor for class org.glassfish.grizzly.utils.DataStructures
 
date - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
DEBUG_MODE - Static variable in class org.glassfish.grizzly.memory.BuffersBuffer
 
DEBUG_MODE - Static variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
DEBUG_MODE - Static variable in class org.glassfish.grizzly.memory.HeapBuffer
 
DebugPoint - Class in org.glassfish.grizzly.utils
Utility class, which may stores the current execution position to help tracking threading issues.
DebugPoint(Exception, String) - Constructor for class org.glassfish.grizzly.utils.DebugPoint
 
dec() - Method in class org.glassfish.grizzly.Writer.Reentrant
Decrements the reentrants counter by one.
decInitialized - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
declaringClass - Variable in class org.glassfish.tyrus.core.ReflectionHelper.DeclaringClassInterfacePair
 
decode(ByteBuffer) - Method in interface javax.websocket.Decoder.Binary
Decode the given bytes into an object of type T.
decode(InputStream) - Method in interface javax.websocket.Decoder.BinaryStream
Decode the given bytes read from the input stream into an object of type T.
decode(String) - Method in interface javax.websocket.Decoder.Text
Decode the given String into an object of type T.
decode(Reader) - Method in interface javax.websocket.Decoder.TextStream
Reads the websocket message from the implementation provided Reader and decodes it into an instance of the supplied object type.
decode(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
decode(Connection, HttpContent) - Method in interface org.glassfish.grizzly.http.ContentEncoding
Decode HTTP packet content represented by HttpContent.
decode(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
decode(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
decode(char[]) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded char array.
decode(byte[]) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded byte array.
decode(String) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded String.
decode(MessageBytes, UDecoder) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the http request represented by the bytes inside MessageBytes using an UDecoder.
decode(MessageBytes, UDecoder, String, B2CConverter) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the HTTP request represented by the bytes inside MessageBytes using an UDecoder, using the specified encoding, using the specified [@link B2CConverter} to decode the request.
decode(DataChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the HTTP request represented by the bytes inside DataChunk.
decode(DataChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the HTTP request represented by the bytes inside DataChunk.
decode(DataChunk, boolean, Charset) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the HTTP request represented by the bytes inside DataChunk.
decode(DataChunk, DataChunk, boolean, Charset) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Decode the HTTP request represented by the bytes inside DataChunk.
decode(DataChunk) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
 
decode(DataChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the DataChunk
decode(DataChunk, DataChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the DataChunk
decode(DataChunk, DataChunk, boolean, String) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the DataChunk
decode(ByteChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the ByteChunk
decode(ByteChunk, ByteChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the ByteChunk
decode(BufferChunk, ByteChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the BufferChunk
decode(ByteChunk, BufferChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the ByteChunk
decode(BufferChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the BufferChunk
decode(BufferChunk, BufferChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the BufferChunk
decode(CharChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the CharChunk
decode(CharChunk, CharChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the CharChunk
decode(CharChunk, CharChunk, boolean, String) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the CharChunk
decode(String) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the String
decode(String, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the String
decode(String, boolean, String) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the String
decode(Transformer<Stream, E>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>, CompletionHandler<E>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Read and decode data from the StreamReader
decode(Transformer<Stream, E>, CompletionHandler<E>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Read and decode data from the StreamReader
decode(char[]) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded char array.
decode(byte[]) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded byte array.
decode(String) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded String.
decode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.InputStreamDecoder
 
decode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.NoOpByteArrayCoder
 
decode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.NoOpByteBufferCoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.NoOpTextCoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.BooleanDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.ByteDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.CharacterDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.DoubleDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.FloatDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.IntegerDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.LongDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders.ShortDecoder
 
decode(String) - Method in class org.glassfish.tyrus.core.coder.ReaderDecoder
 
decode(String, UriComponent.Type) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decodes characters of a string that are percent-encoded octets using UTF-8 decoding (if needed).
decodeAscii(DataChunk, DataChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the DataChunk
decodeAscii(CharChunk, CharChunk, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
URLDecode the CharChunk
decodeAscii(String, boolean) - Static method in class org.glassfish.grizzly.http.util.URLDecoder
 
decodeBit(LZMADecoder.LZMAInputState, short[], int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
decodeDirectBits(LZMADecoder.LZMAInputState, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
DecodeException - Exception in javax.websocket
A general exception that occurs when trying to decode a custom object from a text or binary message.
DecodeException(ByteBuffer, String, Throwable) - Constructor for exception javax.websocket.DecodeException
Constructor with the binary data that could not be decoded, and the reason why it failed to be, and the cause.
DecodeException(String, String, Throwable) - Constructor for exception javax.websocket.DecodeException
Constructor with the text data that could not be decoded, and the reason why it failed to be, and the cause.
DecodeException(ByteBuffer, String) - Constructor for exception javax.websocket.DecodeException
Constructs a DecodedException with the given ByteBuffer that cannot be decoded, and reason why.
DecodeException(String, String) - Constructor for exception javax.websocket.DecodeException
Constructs a DecodedException with the given encoded string that cannot be decoded, and reason why.
decodeFast(char[]) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded char array that is known to be reasonably well formatted.
decodeFast(byte[]) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded byte array that is known to be reasonably well formatted.
decodeFast(String) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Decodes a BASE64 encoded string that is known to be reasonably well formatted.
decodeFast(char[]) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded char array that is known to be reasonably well formatted.
decodeFast(byte[]) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded byte array that is known to be reasonably well formatted.
decodeFast(String) - Static method in class org.glassfish.tyrus.core.Base64Utils
Decodes a BASE64 encoded string that is known to be reasonably well formatted.
decodeHttpPacket(FilterChainContext, HttpPacketParsing, Buffer) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
decodeHttpPacketFromBuffer(FilterChainContext, HttpPacketParsing, Buffer) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
decodeHttpPacketFromBytes(FilterChainContext, HttpPacketParsing, Buffer) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
decodeMatrix(String, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decode the matrix component of a URI path segment.
decodeNormal(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
decodePath(URI, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decode the path component of a URI as path segments.
decodePath(String, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decode the path component of a URI as path segments.
decodePathSegment(List<PathSegment>, String, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
 
decodeQuery(URI, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decode the query component of a URI.
decodeQuery(String, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Decode the query component of a URI.
Decoder - Interface in javax.websocket
The Decoder interface holds member interfaces that define how a developer can provide the web socket container a way web socket messages into developer defined custom objects.
Decoder - Class in org.glassfish.grizzly.compression.lzma.impl
RangeDecoder
Decoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
Decoder.Binary<T> - Interface in javax.websocket
This interface defines how a custom object (of type T) is decoded from a web socket message in the form of a byte buffer.
Decoder.BinaryStream<T> - Interface in javax.websocket
This interface defines how a custom object is decoded from a web socket message in the form of a binary stream.
Decoder.LiteralDecoder - Class in org.glassfish.grizzly.compression.lzma.impl
 
Decoder.LiteralDecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
Decoder.LiteralDecoder.Decoder2 - Class in org.glassfish.grizzly.compression.lzma.impl
 
Decoder.LiteralDecoder.Decoder2() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
Decoder.State - Enum in org.glassfish.grizzly.compression.lzma.impl
 
Decoder.Text<T> - Interface in javax.websocket
This interface defines how a custom object is decoded from a web socket message in the form of a string.
Decoder.TextStream<T> - Interface in javax.websocket
This interface defines how a custom object of type T is decoded from a web socket message in the form of a character stream.
decoder2 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
decoders(List<Class<? extends Decoder>>) - Method in class javax.websocket.ClientEndpointConfig.Builder
Assign the list of decoder implementation classes the client will use.
decoders(List<Class<? extends Decoder>>) - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Sets the decoder implementation classes to use in the configuration.
decodeWithMatchByte(LZMADecoder.LZMAInputState, RangeDecoder, byte) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
decrementDispatchDepth() - Method in class org.glassfish.grizzly.http.server.Request
Decrement the depth of application dispatch
DEFAULT - Static variable in interface org.glassfish.grizzly.Interceptor
 
DEFAULT_ATTRIBUTE_BUILDER - Static variable in interface org.glassfish.grizzly.attributes.AttributeBuilder
The default AttributeBuilder implementation used by all created builder instances.
DEFAULT_ATTRIBUTE_BUILDER - Static variable in class org.glassfish.grizzly.Grizzly
 
DEFAULT_BASE_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.memory.PooledMemoryManager
 
DEFAULT_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
DEFAULT_CAUSE - Static variable in class org.glassfish.grizzly.CloseReason
 
DEFAULT_CHARACTER_ENCODING - Static variable in class org.glassfish.grizzly.utils.Charsets
The default character encoding of this Java virtual machine.
DEFAULT_CHARSET - Static variable in class org.glassfish.grizzly.http.util.ByteChunk
Default encoding used to convert to strings.
DEFAULT_CHARSET - Static variable in class org.glassfish.grizzly.http.util.Parameters
 
DEFAULT_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
Returns the default charset of this Java virtual machine.
DEFAULT_CLIENT_SOCKET_SO_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_CONFIG - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Default SSL configuration.
DEFAULT_CONNECTION_LINGER - Static variable in class org.glassfish.grizzly.http.server.Constants
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in interface org.glassfish.grizzly.SocketConnectorHandler
 
DEFAULT_CONNECTION_UPLOAD_TIMEOUT - Static variable in class org.glassfish.grizzly.http.server.Constants
 
DEFAULT_ENCODING - Static variable in class org.glassfish.grizzly.http.util.Parameters
 
DEFAULT_GROWTH_FACTOR - Static variable in class org.glassfish.grizzly.memory.PooledMemoryManager
 
DEFAULT_HEADER_SIZE - Static variable in class org.glassfish.grizzly.http.server.Constants
Default request header size
DEFAULT_HEADER_SIZE - Static variable in class org.glassfish.grizzly.http.util.MimeHeaders
Initial size - should be == average number of headers per request XXX make it configurable ( fine-tuning of web-apps )
DEFAULT_HEAP_USAGE_PERCENTAGE - Static variable in class org.glassfish.grizzly.memory.PooledMemoryManager
 
DEFAULT_HTTP_CHARACTER_ENCODING - Static variable in class org.glassfish.grizzly.http.util.Constants
Default HTTP character encoding TODO Grizzly 2.0, by default, parsed the request URI using UTF-8.
DEFAULT_HTTP_CHARSET - Static variable in class org.glassfish.grizzly.http.util.CharChunk
Default encoding used to convert to strings.
DEFAULT_HTTP_CHARSET - Static variable in class org.glassfish.grizzly.http.util.Constants
Default HTTP Charset
DEFAULT_HTTP_HEADER_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.http.server.Constants
Default HTTP header buffer size.
DEFAULT_IDLE_THREAD_KEEPALIVE_TIMEOUT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_IN_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.http.GZipContentEncoding
 
DEFAULT_KEEP_ALIVE - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
DEFAULT_LINGER - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
DEFAULT_MAX_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
The maximum size of the memory pool that is to be maintained by either the MemoryManager itself or any ThreadLocalPools.
DEFAULT_MAX_DISPATCH_DEPTH - Static variable in class org.glassfish.grizzly.http.server.Constants
 
DEFAULT_MAX_HTTP_PACKET_HEADER_SIZE - Static variable in class org.glassfish.grizzly.http.HttpCodecFilter
 
DEFAULT_MAX_KEEP_ALIVE - Static variable in class org.glassfish.grizzly.http.util.Constants
Default max keep-alive count.
DEFAULT_MAX_TASKS_QUEUED - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_MAX_THREAD_COUNT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_MEMORY_MANAGER - Static variable in interface org.glassfish.grizzly.memory.MemoryManager
The default MemoryManager implementation used by all created builder instances.
DEFAULT_MIN_THREAD_COUNT - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DEFAULT_NETWORK_HOST - Static variable in class org.glassfish.grizzly.http.server.NetworkListener
The default network host to which the HttpServer will bind to in order to service HTTP requests.
DEFAULT_NETWORK_PORT - Static variable in class org.glassfish.grizzly.http.server.NetworkListener
The default network port to which the HttpServer will bind to in order to service HTTP requests.
DEFAULT_NUMBER_OF_POOLS - Static variable in class org.glassfish.grizzly.memory.PooledMemoryManager
 
DEFAULT_OPTIMIZED_FOR_MULTIPLEXING - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_OUT_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.http.GZipContentEncoding
 
DEFAULT_PREALLOCATED_BUFFERS_PERCENTAGE - Static variable in class org.glassfish.grizzly.memory.PooledMemoryManager
 
DEFAULT_QUEUE_SIZE - Static variable in class org.glassfish.grizzly.http.server.Constants
Default queue in bytes size.
DEFAULT_READ_BUFFER_SIZE - Static variable in interface org.glassfish.grizzly.Transport
The default read buffer size.
DEFAULT_READ_TIMEOUT - Static variable in interface org.glassfish.grizzly.Transport
Default read timeout in seconds.
DEFAULT_RECYCLE - Static variable in class org.glassfish.grizzly.http.server.Constants
Default recycle value.
DEFAULT_REQUEST_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.http.server.Constants
Default request buffer size
DEFAULT_RESPONSE_TYPE - Static variable in class org.glassfish.grizzly.http.server.Constants
The default response-type
DEFAULT_RESPONSE_TYPE - Static variable in class org.glassfish.grizzly.http.util.Constants
The default response-type
DEFAULT_REUSE_ADDRESS - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_SELECTION_KEY_HANDLER - Static variable in interface org.glassfish.grizzly.nio.SelectionKeyHandler
The default SelectionKeyHandler used by all created builder instances.
DEFAULT_SELECTOR_HANDLER - Static variable in interface org.glassfish.grizzly.nio.SelectorHandler
The default SelectorHandler used by all created builder instances.
DEFAULT_SELECTOR_RUNNER_COUNT - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_SELECTORS_COUNT - Static variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
DEFAULT_SERVER_CONNECTION_BACKLOG - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
DEFAULT_SERVER_SOCKET_SO_TIMEOUT - Static variable in class org.glassfish.grizzly.nio.NIOTransport
 
DEFAULT_SERVER_SOCKET_TIMEOUT - Static variable in class org.glassfish.grizzly.http.server.Constants
 
DEFAULT_SMALL_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.memory.ByteBufferManager
TODO: Document
DEFAULT_TCP_NO_DELAY - Static variable in class org.glassfish.grizzly.http.server.Constants
 
DEFAULT_TCP_NO_DELAY - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
DEFAULT_TIMEOUT - Static variable in class org.glassfish.grizzly.http.server.Constants
Default transaction time out.
DEFAULT_WRITE_BUFFER_SIZE - Static variable in interface org.glassfish.grizzly.Transport
The default write buffer size.
DEFAULT_WRITE_TIMEOUT - Static variable in interface org.glassfish.grizzly.Transport
Default write timeout in seconds.
DefaultAttributeBuilder - Class in org.glassfish.grizzly.attributes
Default AttributeBuilder implementation.
DefaultAttributeBuilder() - Constructor for class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
defaultBufferSize - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
DefaultComponentProvider - Class in org.glassfish.tyrus.core
Provides instances using reflection.
DefaultComponentProvider() - Constructor for class org.glassfish.tyrus.core.DefaultComponentProvider
 
defaultConfig() - Static method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Create new Grizzly thread-pool configuration instance.
defaultContextPaths - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Host
 
defaultContexts - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Host
 
defaultEndIdx(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
DefaultErrorPageGenerator - Class in org.glassfish.grizzly.http.server
Default Grizzly ErrorPageGenerator.
DefaultErrorPageGenerator() - Constructor for class org.glassfish.grizzly.http.server.DefaultErrorPageGenerator
 
DefaultFilterChain - Class in org.glassfish.grizzly.filterchain
Default FilterChain implementation
DefaultFilterChain() - Constructor for class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
DefaultFilterChain(Collection<Filter>) - Constructor for class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
DefaultFilterChain.FILTER_STATE_TYPE - Enum in org.glassfish.grizzly.filterchain
 
defaultHostName - Variable in class org.glassfish.grizzly.http.server.util.Mapper
Default host name.
defaultLocale - Static variable in class org.glassfish.grizzly.http.server.Request
The default Locale if none are specified.
DefaultMemoryManagerFactory - Interface in org.glassfish.grizzly.memory
Allows creation/customization of MemoryManager implementation to be used as the MemoryManager.DEFAULT_MEMORY_MANAGER.
DefaultMonitoringConfig<E> - Class in org.glassfish.grizzly.monitoring
Default monitoring configuration, with no JMX support.
DefaultMonitoringConfig(Class<E>) - Constructor for class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
 
DefaultProcessorSelector - Class in org.glassfish.grizzly
Default ProcessorSelector implementation, which uses Connection's Processor preferences.
DefaultProcessorSelector(Transport) - Constructor for class org.glassfish.grizzly.DefaultProcessorSelector
 
DefaultSelectionKeyHandler - Class in org.glassfish.grizzly.nio
 
DefaultSelectionKeyHandler() - Constructor for class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
DefaultSelectorHandler - Class in org.glassfish.grizzly.nio
Default implementation of NIO SelectorHandler
DefaultSelectorHandler() - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
DefaultSelectorHandler(long, TimeUnit) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
DefaultSelectorHandler.DeregisterChannelOperation - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.RegisterChannelOperation - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.RegisterKeyTask - Class in org.glassfish.grizzly.nio
 
DefaultSelectorHandler.RegisterKeyTask(SelectionKey, int) - Constructor for class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
DefaultSelectorHandler.RunnableTask - Class in org.glassfish.grizzly.nio
 
defaultStartIdx(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
DefaultStreamReader - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamReader(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamReader
 
DefaultStreamReader.Input - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamReader.Input() - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
DefaultStreamWriter - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamWriter(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamWriter
 
DefaultStreamWriter.Output - Class in org.glassfish.grizzly.nio.transport
 
DefaultStreamWriter.Output(Connection) - Constructor for class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
DefaultWorkerThread - Class in org.glassfish.grizzly.threadpool
Default Grizzly worker thread implementation
DefaultWorkerThread(AttributeBuilder, String, ThreadLocalPool, Runnable) - Constructor for class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
defaultWrapper - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
deflate(Deflater, MemoryManager) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Writes next block of compressed data to the output stream.
DelayedExecutor - Class in org.glassfish.grizzly.utils
 
DelayedExecutor(ExecutorService) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor
 
DelayedExecutor(ExecutorService, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor
 
DelayedExecutor.DelayQueue<E> - Class in org.glassfish.grizzly.utils
 
DelayedExecutor.DelayQueue(DelayedExecutor.Worker<E>, DelayedExecutor.Resolver<E>) - Constructor for class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
DelayedExecutor.Resolver<E> - Interface in org.glassfish.grizzly.utils
 
DelayedExecutor.Worker<E> - Interface in org.glassfish.grizzly.utils
 
delayedQueue - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
DelayFilter - Class in org.glassfish.grizzly.utils
Filter which pauses protocol chain processing for a certain time.
DelayFilter(long, long) - Constructor for class org.glassfish.grizzly.utils.DelayFilter
 
delayQueue - Variable in class org.glassfish.grizzly.http.server.Response
 
DELETE - Static variable in class org.glassfish.grizzly.http.Method
 
delete(File) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Delete the specified directory, including all of its contents and subdirectories recursively.
delete(int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
delete(int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
delete(int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
delete(int, int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
delete(int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
deleteDir(File) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Delete the specified directory, including all of its contents and subdirectories recursively.
DEPENDENT_CLASS_OF_PROVIDER_FORMAT_ERROR(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
{0}.
DEPENDENT_CLASS_OF_PROVIDER_NOT_FOUND(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
A dependent class, {0}, of the class {1} implementing the provider {2} is not found.
DeploymentException - Exception in javax.websocket
Checked exception indicating some kind of failure either to publish an endpoint on its server, or a failure to connect a client to its server.
DeploymentException(String) - Constructor for exception javax.websocket.DeploymentException
Creates a deployment exception with the given reason for the deployment failure.
DeploymentException(String, Throwable) - Constructor for exception javax.websocket.DeploymentException
Creates a deployment exception with the given reason for the deployment failure and wrapped cause of the failure.
deregister(Object) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Unregister Grizzly JMX Object.
deregisterAddOn(AddOn) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deregisters AddOn from this NetworkListener.
deregisterChannel(SelectorRunner, SelectableChannel) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
deregisterChannel(SelectorRunner, SelectableChannel) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Deregister the channel from the SelectorRunner's Selector.
deregisterChannelAsync(SelectorRunner, SelectableChannel, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
deregisterChannelAsync(SelectorRunner, SelectableChannel, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Deregister the channel from the SelectorRunner's Selector.
deregisterKeyInterest(SelectorRunner, SelectionKey, int) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
Deregisters SelectionKey interest.
deregisterKeyInterest(SelectorRunner, SelectionKey, int) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Deregisters SelectionKey interest.
destroy() - Method in interface javax.websocket.Decoder
This method is called when the decoder is about to be removed from service in order that any resources the encoder used may be closed gracefully.
destroy() - Method in interface javax.websocket.Encoder
This method is called when the encoder is about to be removed from service in order that any resources the encoder used may be closed gracefully.
destroy() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Invoked when the HttpServer and may be overridden by custom implementations to perform implementation specific resource reclaimation tasks.
destroy() - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
 
destroy() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
destroy() - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
destroy() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
destroy() - Method in class org.glassfish.tyrus.core.coder.CoderAdapter
This method does nothing.
destroy(Object) - Method in class org.glassfish.tyrus.core.ComponentProvider
Destroys the given managed instance.
destroy(Object) - Method in class org.glassfish.tyrus.core.DefaultComponentProvider
 
destroy(ExtendedExtension.ExtensionContext) - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension
Context lifecycle method.
destroyDistributedUserProperties(String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Destroy map which holds distributed user properties.
detachSelectorRunner() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
DirContext - Interface in org.glassfish.grizzly.http.server.naming
The directory service interface, containing methods for examining and updating attributes associated with objects, and for searching the directory.
DirectByteBufferRecord - Class in org.glassfish.grizzly.nio
Thread-local Direct ByteBuffer storage.
disableIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
disableIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
disableJMX() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
DISPATCHER_REQUEST_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
Request dispatcher path.
DISPATCHER_TYPE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
Request dispatcher state.
DispatcherHelper - Interface in org.glassfish.grizzly.http.server.util
Interface simplifies by path or name mapping.
dispatcherType - Variable in class org.glassfish.grizzly.http.server.Request
The current dispatcher type.
dispose() - Method in interface org.glassfish.grizzly.Buffer
Notify the allocator that the space for this Buffer is no longer needed.
dispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
dispose() - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
dispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
dispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
disposeBuffer() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
disposeOrder - Variable in class org.glassfish.grizzly.memory.CompositeBuffer
 
disposeOrder() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Returns the order in which internal Buffers will be disposed.
disposeOrder(CompositeBuffer.DisposeOrder) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Sets the order in which internal Buffers will be disposed.
disposeStackTrace - Variable in class org.glassfish.grizzly.memory.BuffersBuffer
 
disposeStackTrace - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
disposeStackTrace - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
DMMF_PROP_NAME - Static variable in interface org.glassfish.grizzly.memory.DefaultMemoryManagerFactory
 
doClose() - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
docRoots - Variable in class org.glassfish.grizzly.http.server.StaticHttpHandler
 
doEncode(Session, Object) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
 
doGetSession(boolean) - Method in class org.glassfish.grizzly.http.server.Request
 
doHandshakeStep(SSLConnectionContext, FilterChainContext, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
doHandshakeStep(SSLConnectionContext, FilterChainContext, Buffer, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
doHandshakeStep(SSLConnectionContext, FilterChainContext, Buffer, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
doHandshakeStep() - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
doHandshakeSync(SSLConnectionContext, FilterChainContext, Buffer, long) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
domain - Variable in class org.glassfish.grizzly.http.Cookie
 
done() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Protected method invoked when this task transitions to state isDone (whether normally or via cancellation).
doNotify() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
doParseHostHeader() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
doRead(Connection, AsyncReadQueueRecord) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Performs real read on the NIO channel
doSelect() - Method in class org.glassfish.grizzly.nio.SelectorRunner
This method handle the processing of all Selector's interest op (OP_ACCEPT,OP_READ,OP_WRITE,OP_CONNECT) by delegating to its Handler.
doWork() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
doWork(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Worker
 
drain(Queue<Runnable>, Collection<Runnable>) - Static method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
drainAllCharsets() - Static method in class org.glassfish.grizzly.utils.Charsets
Remove all preloaded charsets.
drainTo(Collection<? super E>) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
drainTo(Collection<? super E>, int) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
drop(InetAddress, NetworkInterface) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Drops non-source specific membership in a multicast group.
drop(InetAddress, NetworkInterface, InetAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Drops membership in a multicast group.
dropAll(InetAddress, NetworkInterface) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Drops all active membership in a multicast group.
duplicate() - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer that shares this buffer's content.
duplicate(DataChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Copy the src into this DataChunk, allocating more space if needed
duplicate(MessageBytes) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Copy the src into this MessageBytes, allocating more space if needed
duplicate() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
duplicate() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
duplicate() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 

E

EchoFilter - Class in org.glassfish.grizzly.utils
Echo Filter implementation
EchoFilter() - Constructor for class org.glassfish.grizzly.utils.EchoFilter
 
EMatchFinderTypeBT2 - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
EMatchFinderTypeBT4 - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
EMPTY - Static variable in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
The empty pattern that matches the null or empty string.
EMPTY - Static variable in class org.glassfish.tyrus.core.uri.internal.UriTemplate
The empty URI template that matches the null or empty URI path.
EMPTY_BUFFER - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_BYTE_BUFFER - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_BYTE_BUFFER_ARRAY - Static variable in class org.glassfish.grizzly.memory.Buffers
 
EMPTY_PATTERN - Static variable in class org.glassfish.tyrus.core.uri.internal.PathPattern
Empty path pattern matching only empty string.
EMPTY_RECORD_SPACE_VALUE - Static variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
EmptyCompletionHandler<E> - Class in org.glassfish.grizzly
Empty implementation for CompletionHandler interface.
EmptyCompletionHandler() - Constructor for class org.glassfish.grizzly.EmptyCompletionHandler
 
emptyPathWrapper - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
ENABLE_INTEREST_LIFECYCLE_LISTENER - Static variable in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
enabledCipherSuites - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
The list of cipher suite
enabledProtocols - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
the list of protocols
enableIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
enableIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
enableJMX() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
enc - Variable in class org.glassfish.grizzly.http.util.C2BConverter
 
encode(T) - Method in interface javax.websocket.Encoder.Binary
Encode the given object into a byte array.
encode(T, OutputStream) - Method in interface javax.websocket.Encoder.BinaryStream
Encode the given object into a binary stream written to the implementation provided OutputStream.
encode(T) - Method in interface javax.websocket.Encoder.Text
Encode the given object into a String.
encode(T, Writer) - Method in interface javax.websocket.Encoder.TextStream
Encode the given object to a character stream writing it to the supplied Writer.
encode(RangeEncoder, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
encode(short[], int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
encode(Connection, HttpContent) - Method in interface org.glassfish.grizzly.http.ContentEncoding
Encode HTTP packet content represented by HttpContent.
encode(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
encode(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
encode(Transformer<E, Buffer>, E) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
encode(Transformer<E, Buffer>, E, CompletionHandler<Stream>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
encode(Transformer<E, Buffer>, E) - Method in interface org.glassfish.grizzly.streams.StreamWriter
 
encode(Transformer<E, Buffer>, E, CompletionHandler<Stream>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
 
encode(byte[]) - Method in class org.glassfish.tyrus.core.coder.NoOpByteArrayCoder
 
encode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.NoOpByteBufferCoder
 
encode(String) - Method in class org.glassfish.tyrus.core.coder.NoOpTextCoder
 
encode(Object) - Method in class org.glassfish.tyrus.core.coder.ToStringEncoder
 
encode(String, UriComponent.Type) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Encodes the characters of string that are either non-ASCII characters or are ASCII characters that must be percent-encoded using the UTF-8 encoding.
encode(String, UriComponent.Type, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Encodes the characters of string that are either non-ASCII characters or are ASCII characters that must be percent-encoded using the UTF-8 encoding.
encode(Charset, String) - Static method in class org.glassfish.tyrus.core.Utf8Utils
 
encodeDirectBits(int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
EncodeException - Exception in javax.websocket
A general exception that occurs when trying to encode a custom object to a string or binary message.
EncodeException(Object, String) - Constructor for exception javax.websocket.EncodeException
Constructor with the object being encoded, and the reason why it failed to be.
EncodeException(Object, String, Throwable) - Constructor for exception javax.websocket.EncodeException
Constructor with the object being encoded, and the reason why it failed to be, and the cause.
encodeHttpPacket(FilterChainContext, HttpPacket) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
encodeHttpPacket(FilterChainContext, HttpPacket) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
encodeHttpPacket(FilterChainContext, HttpHeader, HttpContent, boolean) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
encodeHttpPacket(FilterChainContext, HttpPacket) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
encodeKnownHeaders(MemoryManager, Buffer, HttpHeader) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
encodeLiteralCharacters(String) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Encode literal characters of a template.
encodeMimeHeader(MemoryManager, Buffer, DataChunk, DataChunk, byte[], boolean) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
encodeMimeHeaders(MemoryManager, Buffer, MimeHeaders, byte[]) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
Encoder - Interface in javax.websocket
The Encoder interface defines how developers can provide a way to convert their custom objects into web socket messages.
Encoder - Class in org.glassfish.grizzly.compression.lzma.impl
RangeEncoder
Encoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
encoder - Variable in class org.glassfish.grizzly.http.util.C2BConverter
 
Encoder.Binary<T> - Interface in javax.websocket
This interface defines how to provide a way to convert a custom object into a binary message.
Encoder.BinaryStream<T> - Interface in javax.websocket
This interface may be implemented by encoding algorithms that want to write the encoded object to a binary stream.
Encoder.Text<T> - Interface in javax.websocket
This interface defines how to provide a way to convert a custom object into a text message.
Encoder.TextStream<T> - Interface in javax.websocket
This interface may be implemented by encoding algorithms that want to write the encoded object to a character stream.
encodeRedirectURL(String) - Method in class org.glassfish.grizzly.http.server.Response
Encode the session identifier associated with this response into the specified redirect URL, if necessary.
encoders(List<Class<? extends Encoder>>) - Method in class javax.websocket.ClientEndpointConfig.Builder
Assign the list of encoder implementation classes the client will use.
encoders(List<Class<? extends Encoder>>) - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Sets the list of encoder implementation classes for this builder.
encodeTemplateNames(String) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Encodes a string with template parameters names present, specifically the characters '{' and '}' will be percent-encoded.
encodeToByte(byte[], boolean) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Encodes a raw byte array into a BASE64 byte[] representation i accordance with RFC 2045.
encodeToByte(byte[], boolean) - Static method in class org.glassfish.tyrus.core.Base64Utils
Encodes a raw byte array into a BASE64 byte[] representation i accordance with RFC 2045.
encodeToChar(byte[], boolean) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Encodes a raw byte array into a BASE64 char[] representation i accordance with RFC 2045.
encodeToChar(byte[], boolean) - Static method in class org.glassfish.tyrus.core.Base64Utils
Encodes a raw byte array into a BASE64 char[] representation i accordance with RFC 2045.
encodeToString(byte[], boolean) - Static method in class org.glassfish.grizzly.http.util.Base64Utils
Encodes a raw byte array into a BASE64 String representation i accordance with RFC 2045.
encodeToString(byte[], boolean) - Static method in class org.glassfish.tyrus.core.Base64Utils
Encodes a raw byte array into a BASE64 String representation i accordance with RFC 2045.
encodeURL(String) - Method in class org.glassfish.grizzly.http.server.Response
Encode the session identifier associated with this response into the specified URL, if necessary.
encodeURL(String) - Method in class org.glassfish.grizzly.http.util.UEncoder
Utility funtion to re-encode the URL.
encodeURL(String, boolean) - Method in class org.glassfish.grizzly.http.util.UEncoder
Utility function to re-encode the URL.
ENCODING_FAILED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Encoding failed.
EncodingFilter - Interface in org.glassfish.grizzly.http
 
END_OF_PATH_PATTERN - Static variable in class org.glassfish.tyrus.core.uri.internal.PathPattern
Path pattern matching the end of a URI path.
Endpoint - Class in javax.websocket
The Web Socket Endpoint represents an object that can handle websocket conversations.
Endpoint() - Constructor for class javax.websocket.Endpoint
 
ENDPOINT_ANNOTATION_NOT_FOUND(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
{0} annotation not found on class {1}.
ENDPOINT_EXCEPTION_FROM_ON_ERROR(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Exception thrown from onError method {0}.
ENDPOINT_MULTIPLE_METHODS(Object, Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Multiple methods using {0} annotation in class {1}: {2} and {3}.
ENDPOINT_MULTIPLE_SESSION_PARAM(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method {0} has got two or more Session parameters.
ENDPOINT_UNHANDLED_EXCEPTION(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Unhandled exception in endpoint {0}.
ENDPOINT_UNKNOWN_PARAMS(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Unknown parameter(s) for {0}.{1} method annotated with @OnError annotation: {2}.
ENDPOINT_WRONG_PARAMS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}.{1}: has got wrong number of params.
ENDPOINT_WRONG_PATH_PARAM(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Method: {0}: {1} is not allowed type for @PathParameter.
EndpointConfig - Interface in javax.websocket
The endpoint configuration contains all the information needed during the handshake process for this end point.
endRequest() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
endsWith(String) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
endsWithSlash() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Check if the URI template ends in a slash ('/').
enque(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
enque(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Execute task in a selector thread.
ensureBufferCapacity(int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
ensureBufferCapacity(int) - Method in interface org.glassfish.grizzly.streams.Output
 
ensureBufferCapacity(int) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
ensureCapacity(int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
entrySet() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
Enumerator<E> - Class in org.glassfish.grizzly.http.server.util
HttpHandler class that wraps an Enumeration around a Java2 collection classes object Iterator so that existing APIs returning Enumerations can easily run on top of the new collections.
Enumerator(Collection<E>) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values of the specified Collection.
Enumerator(Collection<E>, boolean) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values of the specified Collection.
Enumerator(Iterable<E>) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values returned by the specified Iterable.
Enumerator(Iterable<E>, boolean) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values returned by the specified Iterable.
Enumerator(Iterator<E>) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values returned by the specified Iterator.
Enumerator(Iterator<E>, boolean) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values returned by the specified Iterator.
Enumerator(Map<?, E>) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values of the specified Map.
Enumerator(Map<?, E>, boolean) - Constructor for class org.glassfish.grizzly.http.server.util.Enumerator
Return an Enumeration over the values of the specified Map.
equals(Object) - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
equals(Object) - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
equals(Object) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
equals(Object) - Method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
equals(Object) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equals(CharSequence) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equals(byte[]) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the message Buffer to the specified byte array.
equals(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the message Buffer to the specified byte array.
equals(byte[], int, int, Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.BufferChunk
 
equals(char[], int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the message Buffer to the specified char array.
equals(Object) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(String) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Compares the message bytes to the specified String object.
equals(byte[]) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Compares the message bytes to the specified byte array.
equals(ByteChunk) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(CharChunk) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(char[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(byte[], int, int, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(byte[], int, int, String) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
 
equals(Object) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
equals(CharSequence) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified String object.
equals(byte[]) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified byte array representing ASCII characters.
equals(CharChunk) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
equals(char[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
equals(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
equals(String, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equals(String, Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equals(String, String, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equals(Object) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares this DataChunk and the passed object.
equals(String) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message bytes to the specified String object.
equals(ByteChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified ByteChunk.
equals(BufferChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified BufferChunk.
equals(CharChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified CharChunk.
equals(byte[]) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified byte[].
equals(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified byte[].
equals(String) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Compares the message bytes to the specified String object.
equals(Object) - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
equals(Object) - Method in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
equals(Object) - Method in class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
equals(Object) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
equals(Object) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
equals(Object) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
equals(Object) - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
equals(Object) - Method in class org.glassfish.tyrus.core.TyrusExtension
 
equals(Object) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap

This implementation delegates the method call to to the the underlying [key, multi-value] store.

equals(Object) - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
 
equals(Object) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Equality is calculated from the String of the regular expression generated from the templates.
equalsIgnoreCase(Object) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equalsIgnoreCase(CharSequence) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equalsIgnoreCase(byte[]) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equalsIgnoreCase(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
equalsIgnoreCase(char[], int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the message Buffer to the specified char array ignoring case considerations.
equalsIgnoreCase(String) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Compares the message bytes to the specified String object.
equalsIgnoreCase(byte[]) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equalsIgnoreCase(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equalsIgnoreCase(byte[], int, int, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
 
equalsIgnoreCase(byte[], int, int, String) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Compares the message bytes to the specified String object.
equalsIgnoreCase(CharSequence) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified String object.
equalsIgnoreCase(byte[]) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified byte array representing ASCII characters.
equalsIgnoreCase(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified byte array representing ASCII characters.
equalsIgnoreCase(char[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the message bytes to the specified char array representing ASCII characters.
equalsIgnoreCase(String, Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equalsIgnoreCase(String, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equalsIgnoreCase(String, String, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
equalsIgnoreCase(Object) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares this DataChunk and the passed object ignoring case considerations.
equalsIgnoreCase(String) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message bytes to the specified String object ignoring case considerations.
equalsIgnoreCase(ByteChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified ByteChunk ignoring case considerations.
equalsIgnoreCase(BufferChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified BufferChunk ignoring case considerations.
equalsIgnoreCase(CharChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified CharChunk ignoring case considerations.
equalsIgnoreCase(byte[]) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified byte[] ignoring case considerations.
equalsIgnoreCase(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the message data to the specified byte[] ignoring case considerations.
equalsIgnoreCase(String) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Compares the message bytes to the specified String object.
equalsIgnoreCaseLowerCase(byte[]) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the buffer chunk to the specified byte array representing lower-case ASCII characters.
equalsIgnoreCaseLowerCase(Buffer, int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.BufferChunk
Compares the buffer chunk to the specified byte array representing lower-case ASCII characters.
equalsIgnoreCaseLowerCase(byte[]) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
equalsIgnoreCaseLowerCase(byte[], int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Compares the buffer chunk to the specified byte array representing lower-case ASCII characters.
equalsIgnoreCaseLowerCase(byte[]) - Method in class org.glassfish.grizzly.http.util.CharChunk
Compares the char chunk to the specified byte array representing lower-case ASCII characters.
equalsIgnoreCaseLowerCase(byte[]) - Method in class org.glassfish.grizzly.http.util.DataChunk
Compares the data chunk to the specified byte array representing lower-case ASCII characters.
equalsIgnoreValueOrder(MultivaluedMap<K, V>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
equalsIgnoreValueOrder(MultivaluedMap<K, V>) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Compare the specified map with this map for equality modulo the order of values for each key.
equalVersion(int, int) - Static method in class org.glassfish.grizzly.Grizzly
Checks if current Grizzly framework version equals to one passed
EQUIVALENT_PATHS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Found equivalent paths.
error(Throwable) - Method in class org.glassfish.grizzly.http.HttpBrokenContent.Builder
Set the exception.
error - Variable in class org.glassfish.grizzly.http.server.Response
The error flag.
error() - Method in class org.glassfish.tyrus.core.StrictUtf8.Parser
If the previous parse operation detected an error, return the object describing that error.
ERROR_CAUGHT_WHILE_LOADING_SPI_PROVIDERS() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Error caught while loading SPI providers.
ERROR_MESSAGE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward an HTTP status message (as an object of type STring) to an error page.
ErrorCollector - Class in org.glassfish.tyrus.core
Used to collect deployment errors to present these to the user together.
ErrorCollector() - Constructor for class org.glassfish.tyrus.core.ErrorCollector
 
ErrorPageGenerator - Interface in org.glassfish.grizzly.http.server
Error page generator interface, which is responsible for generating of an error page corresponding to the given response status.
Etag - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
evaluate() - Method in interface org.glassfish.grizzly.attributes.NullaryFunction
Deprecated.
Initializes and returns the value.
evaluate() - Method in class org.glassfish.grizzly.utils.Holder.LazyHolder
 
evaluate() - Method in class org.glassfish.grizzly.utils.Holder.LazyIntHolder
 
evaluate() - Method in interface org.glassfish.grizzly.utils.NullaryFunction
Initializes and returns the value.
event - Variable in class org.glassfish.grizzly.filterchain.FilterChainContext
Context associated event, if EVENT operation
exactWrappers - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
EXCEPTION_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward a Java exception (as an object of type Throwable) to an error page.
EXCEPTION_CAUGHT_WHILE_LOADING_SPI_PROVIDERS() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Exception caught while loading SPI providers.
EXCEPTION_PAGE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward the request URI (as an object of type String) of the page on which an error occurred.
EXCEPTION_TYPE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward a Java exception type (as an object of type Class) to an error page.
ExceptionHandler - Interface in org.glassfish.grizzly.utils
 
ExceptionHandler.Severity - Enum in org.glassfish.grizzly.utils
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Notification about exception, occurred on the FilterChain
exceptionOccurred(FilterChainContext, Throwable) - Method in interface org.glassfish.grizzly.filterchain.Filter
Notification about exception, occurred on the FilterChain
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
Override the default implementation to notify the ReadHandler, if available, of any read error that has occurred during processing.
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.utils.LogFilter
 
Exceptions - Class in org.glassfish.grizzly.utils
Exceptions utilities.
Exceptions() - Constructor for class org.glassfish.grizzly.utils.Exceptions
 
execute(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Execute this FilterChain.
execute(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
Method processes occurred IOEvent on this FilterChain.
execute(Filter, FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
execute(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
execute(SelectorRunner, SelectorHandler.Task, CompletionHandler<SelectorHandler.Task>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
Execute task in a selector thread.
execute(Connection, IOEvent, Processor, IOEventLifeCycleListener) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
execute(Context) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.FixedThreadPool
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
execute(Runnable) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
execute() - Method in class org.glassfish.tyrus.container.grizzly.client.TaskProcessor.Task
To be overridden.
executeChainPart(FilterChainContext, FilterExecutor, int, int, DefaultFilterChain.FiltersState) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Sequentially lets each Filter in chain to process IOEvent.
executeDelegatedTask(SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
Complete handshakes operations.
executeFilter(FilterExecutor, Filter, FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Execute the Filter, using specific FilterExecutor and FilterChainContext.
executeInEventThread(IOEvent, Runnable) - Method in interface org.glassfish.grizzly.Connection
Executes the Runnable in the thread, responsible for running the given type of event on this Connection.
executeInEventThread(IOEvent, Runnable) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
executeIoEvent(Connection, IOEvent) - Method in interface org.glassfish.grizzly.IOStrategy
The SelectorRunner will invoke this method to allow the strategy implementation to decide how the IOEvent will be handled.
executeIoEvent(Connection, IOEvent, boolean) - Method in interface org.glassfish.grizzly.IOStrategy
The SelectorRunner will invoke this method to allow the strategy implementation to decide how the IOEvent will be handled.
executeIoEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.LeaderFollowerNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
executeIoEvent(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.glassfish.grizzly.strategies.WorkerThreadIOStrategy
 
ExecutorServiceProvider - Class in org.glassfish.tyrus.core
 
ExecutorServiceProvider() - Constructor for class org.glassfish.tyrus.core.ExecutorServiceProvider
 
expand(URL) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Expand the jar file found at the specified URL into an unpacked directory structure, and return the absolute pathname to the expanded directory.
expand(URL, String) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Expand the jar file found at the specified URL into an unpacked directory structure, and return the absolute pathname to the expanded directory.
expand(URL, String, String) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Expand the jar file found at the specified URL into an unpacked directory structure, and return the absolute pathname to the expanded directory.
expand(InputStream, File, String) - Static method in class org.glassfish.grizzly.http.server.util.ExpandJar
Expand the specified input stream into the specified directory, creating a file named from the specified relative path.
ExpandJar - Class in org.glassfish.grizzly.http.server.util
Expand out a jar.
ExpandJar() - Constructor for class org.glassfish.grizzly.http.server.util.ExpandJar
 
EXPECTATION_FAILED_417 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
EXPECTING_MORE_OPTION - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
 
ExtendedExtension - Interface in org.glassfish.tyrus.core.extension
WebSocket Extension.
ExtendedExtension.ExtensionContext - Interface in org.glassfish.tyrus.core.extension
Context present as a parameter in all ExtendedExtension methods.
Extension - Interface in javax.websocket
A simple representation of a websocket extension as a name and map of extension parameters.
Extension.Parameter - Interface in javax.websocket
This member interface defines a single websocket extension parameter.
EXTENSION_EXCEPTION(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Extension ''{0}'' threw an exception during processOutgoing method invocation: "{1}".
extensions(List<Extension>) - Method in class javax.websocket.ClientEndpointConfig.Builder
Set the extensions for the configuration this builder will build.
extensions(List<Extension>) - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Sets the extensions to use in the configuration.
extensionWrappers - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
extract(int) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Extract and return a substring that starts at the specified position, and extends to the end of the string being parsed.
extract(int, int) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Extract and return a substring that starts at the specified position, and ends at the character before the specified position.
extractContentEncoding(DataChunk) - Method in class org.glassfish.grizzly.http.HttpHeader
Obtain content-encoding value and mark it as serialized.

F

fail(FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fail(FilterChainContext, Throwable) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fail(Throwable) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
failed(Throwable) - Method in interface org.glassfish.grizzly.CompletionHandler
The operation was failed.
failed(Throwable) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The operation was failed.
failed(Throwable) - Method in interface org.glassfish.grizzly.nio.transport.TCPNIOConnection.ConnectResultHandler
 
failed(Throwable) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
failed(Throwable) - Method in class org.glassfish.grizzly.streams.TransformerInput.TransformerCompletionHandler
 
failed(Throwable) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
failed(Throwable) - Method in class org.glassfish.tyrus.spi.CompletionHandler
The operation was failed.
failure(Throwable) - Method in interface org.glassfish.grizzly.impl.FutureImpl
Notify about the failure, occurred during asynchronous operation execution.
failure(Throwable) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Should not be called for ReadyFutureImpl
failure(Throwable) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Notify about the failure, occurred during asynchronous operation execution.
failure - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
failure(Throwable) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Notify about the failure, occured during asynchronous operation execution.
FastDateFormat - Class in org.glassfish.grizzly.http.util
Fast date formatter that caches recently formatted date information and uses it to avoid too-frequent calls to the underlying formatter.
FastDateFormat(DateFormat) - Constructor for class org.glassfish.grizzly.http.util.FastDateFormat
 
FastHttpDateFormat - Class in org.glassfish.grizzly.http.util
Utility class to generate HTTP dates.
FastHttpDateFormat() - Constructor for class org.glassfish.grizzly.http.util.FastHttpDateFormat
 
FileCache - Class in org.glassfish.grizzly.http.server.filecache
This class implements a file caching mechanism used to cache static resources.
FileCache() - Constructor for class org.glassfish.grizzly.http.server.filecache.FileCache
 
FileCache.CacheResult - Enum in org.glassfish.grizzly.http.server.filecache
 
FileCache.CacheType - Enum in org.glassfish.grizzly.http.server.filecache
 
FileCacheEntry - Class in org.glassfish.grizzly.http.server.filecache
The entry value in the file cache map.
FileCacheEntry(FileCache) - Constructor for class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
FileCacheFilter - Class in org.glassfish.grizzly.http.server
 
FileCacheFilter(FileCache) - Constructor for class org.glassfish.grizzly.http.server.FileCacheFilter
 
FileCacheKey - Class in org.glassfish.grizzly.http.server.filecache
The entry key in the file cache map.
FileCacheKey() - Constructor for class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
FileCacheKey(String, String) - Constructor for class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
FileCacheProbe - Interface in org.glassfish.grizzly.http.server.filecache
Monitoring probe providing callbacks that may be invoked by Grizzly FileCache.
FileCacheProbe.Adapter - Class in org.glassfish.grizzly.http.server.filecache
FileCacheProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
FileCacheProbe.Adapter() - Constructor for class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
 
FileTransfer - Class in org.glassfish.grizzly
FileTransfer(File) - Constructor for class org.glassfish.grizzly.FileTransfer
Constructs a new FileTransfer instance backed by the specified File.
FileTransfer(File, long, long) - Constructor for class org.glassfish.grizzly.FileTransfer
Constructs a new FileTransfer instance backed by the specified File.
fill(Buffer, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the Buffer with the specific byte value.
fill(Buffer, int, int, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the Buffer's part [position, limit) with the specific byte value starting from the Buffer's position won't be changed.
fill(ByteBuffer, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the ByteBuffer with the specific byte value.
fill(ByteBuffer, int, int, byte) - Static method in class org.glassfish.grizzly.memory.Buffers
Fill the ByteBuffer's part [position, limit) with the specific byte value starting from the ByteBuffer's position won't be changed.
fillFully(int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
/** Fill the buffer (blocking) up to the requested length.
Filter - Interface in org.glassfish.grizzly.filterchain
A Filter encapsulates a unit of processing work to be performed, whose purpose is to examine and/or modify the state of a transaction that is represented by a FilterChainContext.
filter(String) - Static method in class org.glassfish.grizzly.http.server.Response
Filter the specified message string for characters that are sensitive in HTML.
filter(DataChunk) - Static method in class org.glassfish.grizzly.http.util.HttpStatus
Filter the specified message string for characters that are sensitive in HTML.
filter(String) - Static method in class org.glassfish.grizzly.http.util.HttpStatus
Filter the specified message string for characters that are sensitive in HTML.
filter(String) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
Filter the specified message string for characters that are sensitive in HTML.
FilterChain - Interface in org.glassfish.grizzly.filterchain
This class implement the "Chain of Responsibility" pattern (for more info, take a look at the classic "Gang of Four" design patterns book).
FilterChainBuilder - Class in org.glassfish.grizzly.filterchain
FilterChainBuilder implementation, which is responsible for constructing FilterChains.
FilterChainBuilder.StatelessFilterChainBuilder - Class in org.glassfish.grizzly.filterchain
 
FilterChainBuilder.StatelessFilterChainBuilder() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainBuilder.StatelessFilterChainBuilder
 
FilterChainContext - Class in org.glassfish.grizzly.filterchain
FilterChain Context implementation.
FilterChainContext() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainContext
 
FilterChainContext.CompletionListener - Interface in org.glassfish.grizzly.filterchain
The interface, which represents a listener, which will be notified, once FilterChainContext processing is complete.
FilterChainContext.CopyListener - Interface in org.glassfish.grizzly.filterchain
The interface, which represents a listener, which will be notified, after FilterChainContext.copy() is called.
FilterChainContext.Operation - Enum in org.glassfish.grizzly.filterchain
 
FilterChainContext.State - Enum in org.glassfish.grizzly.filterchain
 
FilterChainContext.TransportContext - Class in org.glassfish.grizzly.filterchain
 
FilterChainContext.TransportContext() - Constructor for class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
FilterChainEnabledTransport - Interface in org.glassfish.grizzly.filterchain
Common interface for Transports, which support FilterChains.
FilterChainEvent - Interface in org.glassfish.grizzly.filterchain
 
FilterChainProcessorSelector - Class in org.glassfish.grizzly.filterchain
ProcessorSelector implementation, which delegates processing of IOEvent to the FilterChain.
FilterChainProcessorSelector(FilterChainBuilder) - Constructor for class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
 
FilterExecutor - Interface in org.glassfish.grizzly.filterchain
Executes appropriate Filter processing method to process occurred IOEvent.
filterNonPrintableCharacters(DataChunk) - Static method in class org.glassfish.grizzly.http.util.HttpStatus
Filter non-printable ASCII characters.
filters - Variable in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
The list of Filters this chain will invoke.
fin(boolean) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set FIN flag.
finalize() - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
finalize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
finalizeShutdown() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
find(String) - Static method in enum org.glassfish.grizzly.http.util.Header
Attempts to find a HTTP header by it's standard textual definition which may differ from value value returned by Enum.name.
find(ByteChunk) - Static method in class org.glassfish.grizzly.http.util.StringCache
Find an entry given its name in the cache and return the associated String.
find(CharChunk) - Static method in class org.glassfish.grizzly.http.util.StringCache
Find an entry given its name in the cache and return the associated String.
find(Class<T>, ClassLoader) - Static method in class org.glassfish.grizzly.utils.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the given class loader.
find(Class<T>) - Static method in class org.glassfish.grizzly.utils.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the context class loader.
find(Class<T>, ClassLoader) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the given class loader.
find(Class<T>, ClassLoader, boolean) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the given class loader.
find(Class<T>) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the context class loader.
find(Class<T>, boolean) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Locates and incrementally instantiates the available providers of a given service using the context class loader.
find(String) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Locates and incrementally instantiates the available classes of a given service file using the context class loader.
findByName(String) - Method in class org.glassfish.grizzly.http.Cookies
 
findBytesAscii(byte[]) - Method in class org.glassfish.grizzly.http.util.BufferChunk
Returns the starting index of the specified byte sequence within this Buffer.
findChar(char) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the index of the next occurrence of the specified character, or the index of the character after the last position of the string if no more occurrences of this character are found.
findChar(byte[], int, int, char) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Find a character, no side effects.
findChars(byte[], int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Find a character, no side effects.
findClosest(ByteChunk, StringCache.ByteEntry[], int) - Static method in class org.glassfish.grizzly.http.util.StringCache
Find an entry given its name in a sorted array of map elements.
findClosest(CharChunk, StringCache.CharEntry[], int) - Static method in class org.glassfish.grizzly.http.util.StringCache
Find an entry given its name in a sorted array of map elements.
findEOL(HttpCodecFilter.HeaderParsingState, Buffer) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
findEOL(HttpCodecFilter.HeaderParsingState, byte[], int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
findMatch(String, List<AlternateDocBase>) - Static method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Attempts to match the given request path against one of the given alternate doc bases.
findMethodOnClass(Class, Method) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Find a method on a class given an existing method.
findNotChars(byte[], int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
Find the first character != c
findSpace(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
findSpace(byte[], int, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
findText() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the index of the next occurrence of a non-whitespace character, or the index of the character after the last position of the string if no more non-whitespace characters are found.
findWhite() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the index of the next occurrence of a whitespace character, or the index of the character after the last position of the string if no more whitespace characters are found.
FINE_GRIZZLY_ASYNCQUEUE_ERROR_NOCALLBACK_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0009: No callback available to be notified about AsyncQueue error: {0}
FINE_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_DEBUG(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
Character decoding failed.
FINE_GRIZZLY_HTTP_PARAMETERS_NOEQUAL(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
Parameter starting at position [{0}] and ending at position [{1}] with a value of [{2}] was not followed by an '=' character
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
finish(AttributeStorage) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Finishes to compress data to the output stream without closing the underlying stream.
finish() - Method in class org.glassfish.grizzly.http.server.Response
Perform whatever actions are required to flush and close the output stream or writer, in a single operation.
finishBufferSlice() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
finished() - Method in class org.glassfish.grizzly.http.io.InputBuffer
When invoked, this method will call ReadHandler.onAllDataRead() on the current ReadHandler (if any).
fireEventDownstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fireEventDownstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fireEventUpstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
fireEventUpstream(Connection, FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
fireIOEvent(IOEvent, Connection, IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
fireIOEvent(IOEvent, Connection, IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
fireIOEvent(Connection, IOEvent, IOEventLifeCycleListener, Logger) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
fireIOEvent(IOEvent, Connection, IOEventLifeCycleListener) - Method in interface org.glassfish.grizzly.Transport
Fires specific IOEvent on the Connection
FixedLengthTransferEncoding - Class in org.glassfish.grizzly.http
Fixed length transfer encoding implementation.
FixedLengthTransferEncoding() - Constructor for class org.glassfish.grizzly.http.FixedLengthTransferEncoding
 
FixedThreadPool - Class in org.glassfish.grizzly.threadpool
Minimalistic fixed thread pool to allow for nice scalability if a good Queue impl is used.
FixedThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.FixedThreadPool
 
flip() - Method in interface org.glassfish.grizzly.Buffer
Flips this buffer.
flip() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
flip() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
flip() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
flush() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
flush(Connection, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
flush(Connection, CompletionHandler<WriteResult>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
flush(CompletionHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
flush() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Flush the response.
flush() - Method in class org.glassfish.grizzly.http.server.Response
Flush the current buffered content to the network.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter
 
flush() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Cause the overflow handler to be called even if buffer is not full.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Cause the overflow handler to be called even if buffer is not full.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
flush(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Output
Make sure that all data that has been written is flushed from the stream to its destination.
flush(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
flush() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Make sure that all data that has been written is flushed from the stream to its destination.
flush(CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Make sure that all data that has been written is flushed from the stream to its destination.
flush() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
flush0(Buffer, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
FLUSH_AND_CLOSE_HANDLER - Static variable in class org.glassfish.grizzly.http.HttpCodecFilter
 
flushAndClose(FilterChainContext) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
Flush the FilterChainContext and close the associated Connection.
flushBatch() - Method in interface javax.websocket.RemoteEndpoint
This method is only used when batching is allowed for this RemoteEndpint.
flushBatch() - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
flushBuffer() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
flushBuffer() - Method in class org.glassfish.grizzly.http.util.C2BConverter
Flush any internal buffers into the ByteOutput or the internal byte[]
flushBuffer() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
flushByteBuffer(SocketChannel, ByteBuffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
flushByteBuffers(SocketChannel, ByteBuffer[], int, int) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
flushData() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
flushSpecialHeaders() - Method in class org.glassfish.grizzly.http.HttpHeader
Flush internal fields for special header names to the headers map.
FORBIDDEN_403 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
FORCED_REQUEST_TYPE - Static variable in class org.glassfish.grizzly.http.server.Constants
The forced request-type
FOREVER - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
FOREVER_SPECIAL - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
forgetWritePossible(WriteHandler) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
fork() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
This method invocation suggests the FilterChain to create a copy of this FilterChainContext and resume/fork its execution starting from the current Filter.
fork(NextAction) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
This method invocation suggests the FilterChain to create a copy of this FilterChainContext and resume/fork its execution starting from the current Filter.
FORM_POST_CONTENT_TYPE - Static variable in class org.glassfish.grizzly.http.util.Constants
 
format - Variable in class org.glassfish.grizzly.http.server.Response
The date format we will use for creating date headers.
format(Date, StringBuffer, FieldPosition) - Method in class org.glassfish.grizzly.http.util.FastDateFormat
Note: breaks functionality of fieldPosition param.
format(Date, StringBuilder, FieldPosition) - Method in class org.glassfish.grizzly.http.util.FastDateFormat
Note: breaks functionality of fieldPosition param.
format(LogRecord) - Method in class org.glassfish.grizzly.utils.LoggingFormatter
Format the record to include the Thread that logged this record.
formatDate(long, DateFormat) - Static method in class org.glassfish.grizzly.http.util.FastHttpDateFormat
Get the HTTP format of the specified date.
http spec only requre second precision http://tools.ietf.org/html/rfc2616#page-20
therefore we dont use the millisecond precision , but second .
FORWARD_CONTEXT_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the original context path is stored on an forwarded dispatcher request.
FORWARD_PATH_INFO_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the original path info is stored on an forwarded dispatcher request.
FORWARD_QUERY_STRING_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the original query string is stored on an forwarded dispatcher request.
FORWARD_REQUEST_URI_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the original request URI is stored on an forwarded dispatcher request.
FORWARD_SERVLET_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the original servlet path is stored on an forwarded dispatcher request.
FOUND_302 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
FRAGMENT_INVALID_OPCODE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Fragment sent but opcode was not 0.
Frame - Class in org.glassfish.tyrus.core.frame
WebSocket frame representation.
Frame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.Frame
Copy constructor.
frame(Frame) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
Frame.Builder - Class in org.glassfish.tyrus.core.frame
Frame builder.
Frame.Builder() - Constructor for class org.glassfish.tyrus.core.frame.Frame.Builder
Constructor.
Frame.Builder(Frame) - Constructor for class org.glassfish.tyrus.core.frame.Frame.Builder
Constructor.
FRAME_WRITE_CANCELLED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Frame writing was canceled.
fromClass(Class<?>, ComponentProviderService, boolean, ErrorCollector) - Static method in class org.glassfish.tyrus.core.AnnotatedEndpoint
Create AnnotatedEndpoint from class.
fromHeaders(List<String>) - Static method in class org.glassfish.tyrus.core.TyrusExtension
Parse Extension from headers (represented as List of strings).
fromInstance(Object, ComponentProviderService, boolean, ErrorCollector) - Static method in class org.glassfish.tyrus.core.AnnotatedEndpoint
Create AnnotatedEndpoint from instance.
fromString(String) - Static method in enum org.glassfish.grizzly.http.CompressionConfig.CompressionMode
Returns the CompressionConfig.CompressionMode based on the string representation.
fromString(List<String>) - Static method in class org.glassfish.tyrus.core.TyrusExtension
Parsing of one Extension.
future - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
FutureImpl<R> - Interface in org.glassfish.grizzly.impl
Future interface, which has full control over the state.
Futures - Class in org.glassfish.grizzly.utils
Set of Future utilities.
Futures() - Constructor for class org.glassfish.grizzly.utils.Futures
 

G

GATEWAY_TIMEOUT_504 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
generate(Request, int, String, String, Throwable) - Method in class org.glassfish.grizzly.http.server.DefaultErrorPageGenerator
Returns the HTML representation of the error page corresponding to the given HTTP response status.
generate(Request, int, String, String, Throwable) - Method in interface org.glassfish.grizzly.http.server.ErrorPageGenerator
Returns the HTML representation of the error page corresponding to the given HTTP response status.
GenericAdapter<K,V> - Interface in org.glassfish.grizzly.utils
Generic Adapter interface.
GenericCloseListener - Interface in org.glassfish.grizzly
Deprecated. 
genericInterface - Variable in class org.glassfish.tyrus.core.ReflectionHelper.DeclaringClassInterfacePair
 
get(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeHolder.
get(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeStorage.
get() - Method in interface org.glassfish.grizzly.Buffer
Relative get method.
get(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method.
get(byte[]) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(byte[], int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(ByteBuffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(ByteBuffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk get method.
get(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
get(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
get(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
get() - Method in class org.glassfish.grizzly.http.Cookies
 
get(FilterChainContext) - Static method in class org.glassfish.grizzly.http.HttpContext
 
GET - Static variable in class org.glassfish.grizzly.http.Method
 
GET - Static variable in class org.glassfish.grizzly.http.server.Constants
GET.
get(HttpRequestPacket) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
get() - Method in class org.glassfish.grizzly.http.util.ContentType
 
get() - Method in class org.glassfish.grizzly.http.util.HeaderValue
 
get(String) - Static method in class org.glassfish.grizzly.http.util.MimeType
 
get(String, String) - Static method in class org.glassfish.grizzly.http.util.MimeType
 
get() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
get(long, TimeUnit) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
get() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
get(long, TimeUnit) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
get() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
get(long, TimeUnit) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
get(ByteBuffer, byte[], int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
get() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
get() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
get() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(byte[]) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
get() - Static method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
get(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
Get the cached object with the given type index from cache.
get() - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
Get (peek) the object from cache.
get() - Method in class org.glassfish.grizzly.utils.Holder
 
get() - Method in class org.glassfish.grizzly.utils.Holder.IntHolder
 
get() - Method in class org.glassfish.grizzly.utils.Holder.LazyHolder
 
get() - Method in class org.glassfish.grizzly.Writer.Reentrant
Returns the value of the reentrants counter for the current thread.
get() - Method in class org.glassfish.tyrus.core.TyrusFuture
 
get(long, TimeUnit) - Method in class org.glassfish.tyrus.core.TyrusFuture
 
get(Object) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
getAccessCount() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getAddOns() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Return the array of the registered AddOns.
getAddOnSet() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Returns the direct addons collection, registered on the NetworkListener.
getAddress() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get address, associated with the current IOEvent processing.
getAddressHolder() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get a Holder, which contains address, associated with the current IOEvent processing.
getAlgorithm() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getAliases() - Method in interface org.glassfish.grizzly.http.ContentEncoding
Get the ContentEncoding aliases.
getAliases() - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
getAliases() - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
getAllMatches(String, Set<TyrusEndpointWrapper>) - Static method in class org.glassfish.tyrus.core.uri.Match
Return a list of all matches, in order of match preference, best match last.
getAllStackTracesAsString() - Static method in class org.glassfish.grizzly.utils.Exceptions
 
getAnnotatedEndpointClasses(Set<Class<?>>) - Method in interface javax.websocket.server.ServerApplicationConfig
Return a set of annotated endpoint classes that the server container must deploy.
getAppBufferSize() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
getApplicationData() - Method in interface javax.websocket.PongMessage
The application data inside the pong message from the peer.
getArguments() - Method in interface org.glassfish.grizzly.localization.Localizable
Returns the arguments for message formatting.
getArguments() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getArguments() - Method in interface org.glassfish.tyrus.core.l10n.Localizable
Returns the arguments for message formatting.
getArguments() - Method in class org.glassfish.tyrus.core.l10n.LocalizableMessage
 
getArray() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getArray() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
getArray() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the underlying array.
getArrayClass(Class) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get Array class of component class.
getArrayCopy() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the copy of the underlying array.
getArraySize() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
getAsyncQueueIO() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueEnabledTransport
Get asynchronous queue implementation.
getAsyncQueueIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getAsyncQueueIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getAsyncReadQueue() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAsyncRemote() - Method in interface javax.websocket.Session
Return a reference a RemoteEndpoint object representing the peer of this conversation that is able to send messages asynchronously to the peer.
getAsyncRemote() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getAsyncRemote() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getAsyncWriteQueue() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Return an object based on a name.
getAttribute(int) - Method in interface org.glassfish.grizzly.attributes.IndexedAttributeAccessor
Internal method for dynamic attribute support.
getAttribute(String) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Return an object based on a name.
getAttribute(int) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
Internal method for dynamic attribute support.
getAttribute(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the specified request attribute if it exists; otherwise, return null.
getAttribute(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the specified request attribute if it exists; otherwise, return null.
getAttribute(String) - Method in class org.glassfish.grizzly.http.server.Session
Return an attribute.
getAttributeBuilder() - Method in class org.glassfish.grizzly.AbstractTransport
Get Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
getAttributeBuilder() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Get AttributeBuilder, associated with this holder
getAttributeBuilder() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Get AttributeBuilder, associated with this holder
getAttributeBuilder() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getAttributeBuilder() - Method in interface org.glassfish.grizzly.Transport
Get Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
getAttributeByIndex(int) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
getAttributeByName(String) - Method in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
getAttributeNames() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Return a Set of attribute names.
getAttributeNames() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Return a Set of attribute names.
getAttributeNames() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the names of all request attributes for this Request, or an empty Set if there are none.
getAttributeNames() - Method in class org.glassfish.grizzly.http.server.Request
Return the names of all request attributes for this Request, or an empty Set if there are none.
getAttributes() - Method in interface org.glassfish.grizzly.attributes.AttributeStorage
Get associated AttributeHolder.
getAttributes() - Method in class org.glassfish.grizzly.Context
Get attributes (AttributeHolder), associated with the processing Context.
getAttributes() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get associated AttributeHolder.
getAttributes() - Method in class org.glassfish.grizzly.http.HttpContext
 
getAttributes() - Method in class org.glassfish.grizzly.http.HttpHeader
Get associated AttributeHolder.
getAttributes() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getAttributes() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getAuthorization() - Method in class org.glassfish.grizzly.http.server.Request
Return the authorization credentials sent with this request.
getAuthType() - Method in class org.glassfish.grizzly.http.server.Request
Return the authentication type used for this Request.
getBasePath() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the absolute doc base path of this AlternateDocBase.
getBasicRemote() - Method in interface javax.websocket.Session
Return a reference a RemoteEndpoint object representing the peer of this conversation that is able to send messages synchronously to the peer.
getBasicRemote() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getBasicRemote() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getBatchingAllowed() - Method in interface javax.websocket.RemoteEndpoint
Return whether the implementation is allowed to batch outgoing messages before sending.
getBatchingAllowed() - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
getBestMatch(String, Set<TyrusEndpointWrapper>) - Static method in class org.glassfish.tyrus.core.uri.Match
Returns null, or a Match object
getBuffer() - Method in interface org.glassfish.grizzly.http.io.BinaryNIOInputSource
Returns the the duplicate of the underlying Buffer that backs this InputSource.
getBuffer() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Returns the duplicate of the underlying Buffer used to buffer incoming request data.
getBuffer() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
getBuffer() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns the message bytes.
getBuffer() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getBuffer() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
getBuffer() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
getBuffer() - Method in interface org.glassfish.grizzly.streams.Input
Return the Input's Buffer.
getBuffer() - Method in interface org.glassfish.grizzly.streams.Output
Return the Input's Buffer.
getBuffer() - Method in class org.glassfish.grizzly.streams.StreamInput
 
getBuffer() - Method in class org.glassfish.grizzly.streams.StreamOutput
 
getBuffer() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
Get the result Buffer (not flipped).
getBufferAppender(boolean) - Static method in class org.glassfish.grizzly.memory.Buffers
Get the Appender which knows how to append Buffers.
getBufferChunk() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
getBufferedDataSize() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Get the number of bytes buffered on OutputBuffer and ready to be sent.
getBufferedSize() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
getBufferSize() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
getBufferSize() - Method in class org.glassfish.grizzly.http.server.Response
Return the actual buffer size used for this Response.
getBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
getBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
getByFilename(String) - Static method in class org.glassfish.grizzly.http.util.MimeType
 
getByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
getByteArray() - Method in class org.glassfish.grizzly.http.util.ContentType
 
getByteArray() - Method in class org.glassfish.grizzly.http.util.HeaderValue
 
getByteBuffer(boolean) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
Returns the entry's ByteBuffer representation.
getByteChunk() - Method in class org.glassfish.grizzly.http.util.C2BConverter
 
getByteChunk() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
getByteChunk() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns the byte chunk, representing the byte[] and offset/length.
getByteEnabled() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getBytes() - Method in exception javax.websocket.DecodeException
Return the ByteBuffer containing either the whole message, or the partial message, that could not be decoded, or null if this exception arose from a failure to decode a text message.
getBytes() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns the message bytes.
getBytes() - Method in enum org.glassfish.grizzly.http.util.Header
Returns the byte representation of this header encoded using ISO-8859-1.
getCacheSize() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getCause() - Method in class org.glassfish.grizzly.CloseReason
Returns information about an error, that caused the Connection to be closed.
getCertificates() - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter.CertificateEvent
 
getChannel() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getChannel() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getChar() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a char value.
getChar(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a char value.
getChar() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getChar(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getChar() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getChar(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getChar() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getChar(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getCharacterEncoding() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getCharacterEncoding() - Method in class org.glassfish.grizzly.http.server.Request
Return the character encoding for this Request.
getCharacterEncoding() - Method in class org.glassfish.grizzly.http.server.Response
Return the character encoding used for this Response.
getCharacterEncoding() - Method in class org.glassfish.grizzly.http.util.ContentType
 
getCharChunk() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
getCharChunk() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns the char chunk, representing the char[] and offset/length.
getCharEnabled() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getChars() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getCharset() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getCharset() - Method in class org.glassfish.grizzly.utils.StringDecoder
 
getCharset() - Method in class org.glassfish.grizzly.utils.StringEncoder
 
getCharsetDecoder(Charset) - Static method in class org.glassfish.grizzly.utils.Charsets
Return the Charset's CharsetDecoder.
getCharsetEncoder(Charset) - Static method in class org.glassfish.grizzly.utils.Charsets
Return the Charset's CharsetEncoder.
getCharsetFromContentType(String) - Static method in class org.glassfish.grizzly.http.util.ContentType
Parse the character encoding from the specified content type header.
getChunkSize() - Method in class org.glassfish.grizzly.utils.ChunkingFilter
 
getCipherSuite() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The cipher suite being used on this connection.
getCipherSuite() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getClass(Class, Class) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Find the declaring class that implements or extends an interface.
getClassLoader() - Method in class org.glassfish.grizzly.http.server.CLStaticHttpHandler
Returns the ClassLoader used to resolve the requested HTTP resources.
getClassType(Class<?>, Class<?>) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Find a type of the class given it's Superclass.
getClazz() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getClientSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getClientSocketSoTimeout() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getClientSSLEngineConfig() - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
getClone() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getClone() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getClone() - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
getCloseable() - Method in class org.glassfish.grizzly.http.HttpContext
 
getCloseCode(int) - Static method in enum javax.websocket.CloseReason.CloseCodes
Creates a CloseCode from the given int code number.
getCloseCode() - Method in class javax.websocket.CloseReason
The Close code associated with this CloseReason.
getCloseListener() - Method in interface org.glassfish.tyrus.spi.Connection
Returns the same close listener that is passed for creating connection in WebSocketEngine.UpgradeInfo#createConnection(Writer, CloseListener).
getCloseReason() - Method in interface org.glassfish.grizzly.Connection
Returns CloseReason if this Connection has been closed, or null otherwise.
getCloseReason() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getCloseReason() - Method in enum org.glassfish.tyrus.core.CloseReasons
Get close reason.
getCloseReason() - Method in class org.glassfish.tyrus.core.frame.CloseFrame
Get close reason.
getCloseReason() - Method in exception org.glassfish.tyrus.core.ProtocolException
 
getCloseReason() - Method in exception org.glassfish.tyrus.core.Utf8DecodingException
 
getCloseReason() - Method in exception org.glassfish.tyrus.core.WebSocketException
Get close reason.
getCode() - Method in interface javax.websocket.CloseReason.CloseCode
Returns the code number, for example the integer '1000' for normal closure.
getCode() - Method in enum javax.websocket.CloseReason.CloseCodes
Return the code number of this status code.
getCoder() - Method in class org.glassfish.tyrus.core.coder.CoderWrapper
Get coder instance.
getCoderClass() - Method in class org.glassfish.tyrus.core.coder.CoderWrapper
Get coder class.
getCoderInstance(Class<T>, Session, EndpointConfig, ErrorCollector) - Method in class org.glassfish.tyrus.core.ComponentProviderService
Provide an instance of Encoder or Decoder descendant which is coupled to Session.
getComment() - Method in class org.glassfish.grizzly.http.Cookie
Returns the comment describing the purpose of this cookie, or null if the cookie has no comment.
getComment() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getCompletionHandler() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
getCompletionHandler() - Method in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
getCompletionHandler() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
getCompletionHandler() - Method in interface org.glassfish.grizzly.http.server.SuspendContext
Get the suspended Response CompletionHandler.
getCompletionHandler() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getCompressableMimeTypes() - Method in class org.glassfish.grizzly.http.CompressionConfig
Returns the read-only set of the mime-types, which are allowed to be compressed.
getCompressedFilesFolder() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Returns the folder to be used to store temporary compressed files.
getCompressibleMimeTypes() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().getCompressableMimeTypes()
getCompression() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().getCompressionMode().name()
getCompressionConfig() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Returns the FileCache compression configuration settings.
getCompressionConfig() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Returns CompressionConfig configuration.
getCompressionLevel(String) - Static method in enum org.glassfish.grizzly.http.server.CompressionLevel
Deprecated.
Set compression level.
getCompressionMinSize() - Method in class org.glassfish.grizzly.http.CompressionConfig
Returns the minimum size of an entity, which will be compressed.
getCompressionMinSize() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().getCompressionMinSize()
getCompressionMode() - Method in class org.glassfish.grizzly.http.CompressionConfig
getConcurrentMap() - Static method in class org.glassfish.grizzly.utils.DataStructures
Creates a new, empty map with a default initial capacity (16), load factor (0.75) and concurrencyLevel (16).
getConcurrentMap(Map<? extends K, ? extends V>) - Static method in class org.glassfish.grizzly.utils.DataStructures
Creates a new map with the same mappings as the given map.
getConcurrentMap(int) - Static method in class org.glassfish.grizzly.utils.DataStructures
Creates a new, empty map with an initial table size accommodating the specified number of elements without the need to dynamically resize.
getConcurrentMap(int, float, int) - Static method in class org.glassfish.grizzly.utils.DataStructures
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity), table density (loadFactor), and number of concurrently updating threads (concurrencyLevel).
getCondition() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getConfig() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getConfiguration() - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
getConfiguration() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
getConfigurator() - Method in interface javax.websocket.ClientEndpointConfig
Return the custom configurator for this configuration.
getConfigurator() - Method in interface javax.websocket.server.ServerEndpointConfig
Return the ServerEndpointConfig.Configurator this configuration is using.
getConnection() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
getConnection() - Method in class org.glassfish.grizzly.Context
Get the processing Connection.
getConnection() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the Connection, associated with the current processing.
getConnection() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getConnection() - Method in class org.glassfish.grizzly.ReadResult
Get the Connection data were read from.
getConnection() - Method in interface org.glassfish.grizzly.Result
Get Connection, associated with the result.
getConnection() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
getConnection() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the Connection this StreamReader belongs to.
getConnection() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Get the Connection this StreamWriter belongs to.
getConnection() - Method in interface org.glassfish.grizzly.streams.Stream
Get the Connection this StreamReader belongs to.
getConnection() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Get the Connection this StreamWriter belongs to.
getConnection() - Method in class org.glassfish.grizzly.WriteResult
Get the Connection data were read from.
getConnectionConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the connection monitoring config.
getConnectionForKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
getConnectionForKey(SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
getConnectionMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the monitoring configuration for Transport Connections.
getConnectionMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the monitoring configuration for Transport Connections.
getConnectionTimeout() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getConnectionTimeout() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getContainer() - Method in class javax.websocket.ContainerProvider
Load the container implementation.
getContainer() - Method in interface javax.websocket.Session
Return the container that this session is part of.
getContainer() - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyContainerProvider
 
getContainer() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Not supported (yet?).
getContainer() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getContent() - Method in class org.glassfish.grizzly.http.HttpBrokenContent
Get the HTTP message content Buffer.
getContent() - Method in class org.glassfish.grizzly.http.HttpContent
Get the HTTP message content Buffer.
getContentEncodings() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Gets registered ContentEncodings.
getContentEncodings(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
 
getContentEncodings() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getContentLanguage() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
getContentLength() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the content-length of this HttpPacket.
getContentLength() - Method in class org.glassfish.grizzly.http.server.Request
Return the content length for this Request.
getContentLength() - Method in class org.glassfish.grizzly.http.server.Response
Return the content length that was set or calculated for this Response.
getContentLengthLong() - Method in class org.glassfish.grizzly.http.server.Request
Return the content length for this Request represented by Java long type.
getContentLengthLong() - Method in class org.glassfish.grizzly.http.server.Response
Return the content length that was set or calculated for this Response.
getContentParsingState() - Method in interface org.glassfish.grizzly.http.HttpPacketParsing
 
getContentType() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getContentType() - Method in class org.glassfish.grizzly.http.server.Request
Return the content type for this Request.
getContentType() - Method in class org.glassfish.grizzly.http.server.Response
Return the content type that was set or calculated for this response, or null if no content type was set.
getContentTypeHolder() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getContext() - Method in class org.glassfish.grizzly.http.server.Request
 
getContextClassLoader() - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the context class loader.
getContextNames() - Method in class org.glassfish.grizzly.http.server.util.Mapper
Return all contexts, in //HOST/PATH form
getContextPath() - Method in class org.glassfish.grizzly.http.server.Request
Returns the portion of the request URI that indicates the context of the request.
getContextStorage() - Method in class org.glassfish.grizzly.http.HttpContext
 
getCookieHeaderName() - Method in class org.glassfish.grizzly.http.Cookie
Return the header name to set the cookie, based on cookie version.
getCookieHeaderName(int) - Static method in class org.glassfish.grizzly.http.Cookie
Return the header name to set the cookie, based on cookie version.
getCookies() - Method in class org.glassfish.grizzly.http.server.Request
Return the set of Cookies received with this Request.
getCookies() - Method in class org.glassfish.grizzly.http.server.Response
Return an array of all cookies set for this response, or a zero-length array if no cookies have been set.
getCorePoolSize() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getCrc32() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getCreationTime() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
getCurrentDate() - Static method in class org.glassfish.grizzly.http.util.FastHttpDateFormat
Get the current date in HTTP format.
getCurrentDateBytes() - Static method in class org.glassfish.grizzly.http.util.FastHttpDateFormat
Get the current date in HTTP format.
getCurrentResult() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
Returns the current record result object.
getCurrentResult() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
getCurrentResult() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getCurrentSet() - Method in class org.glassfish.grizzly.http.util.Parameters
 
getData() - Method in class org.glassfish.grizzly.ProcessorResult
Get the ProcessorResult extra data.
getDateHeader(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the value of the specified date header, if any; otherwise return -1.
getDateHeader(Header) - Method in class org.glassfish.grizzly.http.server.Request
Return the value of the specified date header, if any; otherwise return -1.
getDecBytes() - Static method in class org.glassfish.grizzly.http.util.HexUtils
 
getDeclaringClass(AccessibleObject) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
 
getDecodedRequestURI() - Method in class org.glassfish.grizzly.http.server.Request
Get the decoded request URI.
getDecodedRequestURIBC() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecodedRequestURIBC(boolean) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecodedRequestURIBC(boolean, Charset) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecodedURI() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecodedURI(boolean) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecodedURI(boolean, Charset) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDecoder() - Method in interface org.glassfish.grizzly.Codec
 
getDecoder() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getDecoder() - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
getDecoder() - Method in class org.glassfish.grizzly.ssl.SSLCodec
getDecoders() - Method in interface javax.websocket.EndpointConfig
Return the Decoder implementation classes configured.
getDecodeStatus() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getDefaultAsyncSendTimeout() - Method in interface javax.websocket.WebSocketContainer
Return the number of milliseconds the implementation will timeout attempting to send a websocket message for all RemoteEndpoints associated with this container.
getDefaultAsyncSendTimeout() - Method in class org.glassfish.tyrus.client.ClientManager
 
getDefaultDocRoot() - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Return the default directory from where files will be serviced.
getDefaultErrorPageGenerator() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Returns the NetworkListener default ErrorPageGenerator.
getDefaultErrorPageGenerator() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Returns the default ErrorPageGenerator.
getDefaultHostName() - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
getDefaultMaxBinaryMessageBufferSize() - Method in interface javax.websocket.WebSocketContainer
Returns the default maximum size of incoming binary message that this container will buffer.
getDefaultMaxBinaryMessageBufferSize() - Method in class org.glassfish.tyrus.client.ClientManager
 
getDefaultMaxSessionIdleTimeout() - Method in interface javax.websocket.WebSocketContainer
Return the default time in milliseconds after which any web socket sessions in this container will be closed if it has been inactive.
getDefaultMaxSessionIdleTimeout() - Method in class org.glassfish.tyrus.client.ClientManager
 
getDefaultMaxTextMessageBufferSize() - Method in interface javax.websocket.WebSocketContainer
Returns the default maximum size of incoming text message that this container will buffer.
getDefaultMaxTextMessageBufferSize() - Method in class org.glassfish.tyrus.client.ClientManager
 
getDefaultQueryEncoding() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Returns the default character encoding used to decode request URI's query part.
getDefaultResponseContentType() - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
getDefaultSelectorRunnersCount() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getDefaultSelectorRunnersCount() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getDefaultThreadFactory() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getDefaultURIEncoding() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getDetailMessage() - Method in class org.glassfish.grizzly.http.server.Response
Gets detail error message.
getDictionarySize() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getDigest() - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
getDirectBuffer() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
getDirectBufferSlice() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
getDistributedSessionProperties(String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Get the map containing session properties to be shared among nodes.
getDistributedUserProperties(String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Get the map containing session user properties to be shared among nodes.
getDocBase() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the (possibly relative) doc base path of this AlternateDocBase.
getDocRoots() - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Return the list of directories where files will be serviced from.
getDomain() - Method in class org.glassfish.grizzly.http.Cookie
Returns the domain name set for this cookie.
getDomain() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getDotedVersion() - Static method in class org.glassfish.grizzly.Grizzly
Return the dotted version of the current release.
getDouble() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a double value.
getDouble(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a double value.
getDouble() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getDouble() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getDouble() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getDouble(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getDst() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getDst() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getDstAddress() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getDstAddress() - Method in class org.glassfish.grizzly.WriteResult
Get the destination address, the message was written to.
getDstAddressHolder() - Method in class org.glassfish.grizzly.WriteResult
Get the destination address, the message was written to.
getEnabledCipherSuites() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getEnabledProtocols() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getEncoder() - Method in interface org.glassfish.grizzly.Codec
 
getEncoder() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getEncoder() - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
getEncoder() - Method in class org.glassfish.grizzly.ssl.SSLCodec
getEncoders() - Method in interface javax.websocket.EndpointConfig
Return the Encoder implementation classes configured.
getEncoding() - Method in class org.glassfish.grizzly.http.util.C2BConverter
 
getEncoding() - Method in class org.glassfish.grizzly.http.util.Parameters
 
getEnd() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
getEnd() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getEnd() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getEnd() - Method in interface org.glassfish.grizzly.http.util.Chunk
 
getEnd() - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns the DataChunk end position.
getEndIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getEndpointClass() - Method in interface javax.websocket.server.ServerEndpointConfig
Returns the Class of the endpoint this configuration is configuring.
getEndpointConfig() - Method in class org.glassfish.tyrus.core.AnnotatedEndpoint
 
getEndpointConfig() - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Get Endpoint configuration.
getEndpointConfigs(Set<Class<? extends Endpoint>>) - Method in interface javax.websocket.server.ServerApplicationConfig
Return a set of ServerEndpointConfig instances that the server container will use to deploy the programmatic endpoints.
getEndpointInstance(Class<T>) - Method in class javax.websocket.server.ServerEndpointConfig.Configurator
This method is called by the container each time a new client connects to the logical endpoint this configurator configures.
getEndpointInstance(Class<T>) - Method in class org.glassfish.tyrus.core.ComponentProviderService
This method is called by the container each time a new client connects to the logical endpoint this configurator configures.
getEndpointPath() - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Get Endpoint absolute path.
getEndpointWrapper() - Method in class org.glassfish.tyrus.core.uri.Match
getErrorCode() - Method in class org.glassfish.grizzly.TransformationResult
 
getErrorDescription() - Method in class org.glassfish.grizzly.TransformationResult
 
getErrorPage(String, String, String) - Static method in class org.glassfish.grizzly.http.server.util.HtmlHelper
 
getErrorPageGenerator(Request) - Method in class org.glassfish.grizzly.http.server.HttpHandler
Returns the ErrorPageGenerator, that might be used (if an error occurs) during Request processing.
getErrorPageGenerator() - Method in class org.glassfish.grizzly.http.server.Response
 
getException() - Method in class javax.websocket.SendResult
The problem sending the message.
getException() - Method in class org.glassfish.grizzly.http.HttpBrokenContent
Returns Throwable, which describes the error.
getExceptionErrorPage(String, String, String, Throwable) - Static method in class org.glassfish.grizzly.http.server.util.HtmlHelper
 
getExecutor(Request) - Method in interface org.glassfish.grizzly.http.server.RequestExecutorProvider
Returns the Executor to execute user's code associated with the Request processing.
getExecutor(Request) - Method in class org.glassfish.grizzly.http.server.RequestExecutorProvider.SameThreadProvider
 
getExecutor(Request) - Method in class org.glassfish.grizzly.http.server.RequestExecutorProvider.WorkerThreadProvider
 
getExecutorService() - Method in class org.glassfish.tyrus.core.BaseContainer
 
getExecutorService() - Method in class org.glassfish.tyrus.core.ExecutorServiceProvider
getExtensions() - Method in interface javax.websocket.ClientEndpointConfig
Return the extensions, in order of preference, favorite first, that this client would like to use for its sessions.
getExtensions() - Method in interface javax.websocket.server.ServerEndpointConfig
Return the websocket extensions configured.
getExternalRemainder() - Method in class org.glassfish.grizzly.TransformationResult
 
getFile(boolean) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
Returns the entry's File reference.
getFileCache() - Method in class org.glassfish.grizzly.http.server.FileCacheFilter
 
getFileCache() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getFileCacheConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the file cache monitoring config.
getFileSize(boolean) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
Returns the entry file size.
getFilterChain() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get FilterChain, which runs the Filter.
getFilterChain() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getFirst() - Method in class org.glassfish.grizzly.utils.Pair
 
getFirst(K) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
getFirst(K) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
A shortcut to get the first value of the supplied key.
getFirst(String, Class<A>) - Method in class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
getFirst(String, A) - Method in class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
getFirstHeaderValue(String) - Method in class org.glassfish.tyrus.spi.UpgradeResponse
Gets the value of the response header with the given name.
getFloat() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a float value.
getFloat(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a float value.
getFloat() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getFloat() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getFloat() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getFloat(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getForkAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getForkAction(NextAction) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getFormats() - Method in class org.glassfish.grizzly.http.server.util.SimpleDateFormats
 
getFromCache(ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Get the cached object with the given type index from cache.
getFromCache(Thread, ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Get the cached object with the given type index from cache.
getFromCache(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
Get the cached object with the given type index from cache.
getFromStringStringMethod(Class) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the static fromString(String ) method.
getFullServerName() - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
getFuture() - Method in class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
getGenericClass(Type) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the class that is the type argument of a parameterized type.
getGroupCounts() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the capturing group counts for each template variable.
getGroupIndexes() - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Get the group indexes.
getGroupIndexes() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the group indexes to capturing groups.
getGzipAliases() - Static method in class org.glassfish.grizzly.http.GZipContentEncoding
 
getHandshakeTimeout(TimeUnit) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
Returns the handshake timeout, -1 if blocking handshake mode is disabled (default).
getHeader(String) - Method in class org.glassfish.grizzly.http.HttpHeader
Get the value, of the specific HTTP mime header.
getHeader(Header) - Method in class org.glassfish.grizzly.http.HttpHeader
Get the value, of the specific HTTP mime header.
getHeader(String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Get the value, of the specific HTTP mime header.
getHeader(Header) - Method in class org.glassfish.grizzly.http.HttpTrailer
Get the value, of the specific HTTP mime header.
getHeader(String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Get the value, of the specific HTTP mime header.
getHeader(Header) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Get the value, of the specific HTTP mime header.
getHeader(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the first value of the specified header, if any; otherwise, return null
getHeader(Header) - Method in class org.glassfish.grizzly.http.server.Request
Return the first value of the specified header, if any; otherwise, return null
getHeader(String) - Method in class org.glassfish.grizzly.http.server.Response
Return the value for the specified header, or null if this header has not been set.
getHeader(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
getHeader(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
getHeader(String) - Method in class org.glassfish.tyrus.core.RequestContext
Returns the header value corresponding to the name.
getHeader(String) - Method in class org.glassfish.tyrus.spi.UpgradeRequest
Returns the value of the specified request header name.
getHeaderFlag() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getHeaderFromList(List<T>) - Static method in class org.glassfish.tyrus.core.Utils
Creates single String value from provided List by calling Object.toString() on each item and separating existing ones with ", ".
getHeaderFromList(List<T>, Utils.Stringifier<T>) - Static method in class org.glassfish.tyrus.core.Utils
Convert list of values to singe String usable as HTTP header value.
getHeaderNames() - Method in class org.glassfish.grizzly.http.server.Request
Return the names of all headers received with this request.
getHeaderNames() - Method in class org.glassfish.grizzly.http.server.Response
Return an array of all the header names set for this response, or a zero-length array if no headers have been set.
getHeaderParseStateValue() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getHeaderParsingState() - Method in interface org.glassfish.grizzly.http.HttpPacketParsing
 
getHeaders() - Method in interface javax.websocket.HandshakeResponse
Return the list of Http headers sent by the web socket server.
getHeaders() - Method in interface javax.websocket.server.HandshakeRequest
Return the read only Map of Http Headers that came with the handshake request.
getHeaders() - Method in class org.glassfish.grizzly.http.HttpHeader
Get all MimeHeaders, associated with the HttpHeader.
getHeaders() - Method in interface org.glassfish.grizzly.http.HttpPacketParsing
 
getHeaders() - Method in class org.glassfish.grizzly.http.HttpTrailer
Get all MimeHeaders, associated with the HttpHeader.
getHeaders() - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Get all MimeHeaders, associated with the HttpHeader.
getHeaders(String) - Method in class org.glassfish.grizzly.http.server.Request
Return all of the values of the specified header, if any; otherwise, return an empty enumeration.
getHeaders(Header) - Method in class org.glassfish.grizzly.http.server.Request
Return all of the values of the specified header, if any; otherwise, return an empty enumeration.
getHeaders() - Method in class org.glassfish.tyrus.core.RequestContext
Get headers.
getHeaders() - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
Get HTTP headers.
getHeaderValues(String) - Method in class org.glassfish.grizzly.http.server.Response
Return an array of all the header values associated with the specified header name, or an zero-length array if there are no such header values.
getHeapCacheSize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Return the heap space used for cache
getHitCount() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getHost() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
getHost() - Method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
getHost() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getHosts() - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
getHttpCodecFilter() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getHttpConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the http monitoring config.
getHttpContent() - Method in class org.glassfish.grizzly.http.ParsingResult
 
getHttpFilter() - Method in class org.glassfish.grizzly.http.server.Request
 
getHttpHandler() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
getHttpHandler() - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
getHttpHandlerPath() - Method in class org.glassfish.grizzly.http.server.Request
Returns the part of this request's URL that calls the HttpHandler.
getHttpHandlers() - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Returns the HttpHandler map.
getHttpHeader() - Method in class org.glassfish.grizzly.http.HttpContent
Get the HTTP message header, associated with this content.
getHttpHeader() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns this HttpHeader object.
getHttpHeader() - Method in class org.glassfish.grizzly.http.HttpPacket
Get the HTTP message header, associated with this HTTP packet.
getHttpServerFilter() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getHttpServerName() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
getHttpServerVersion() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
getHttpSession() - Method in interface javax.websocket.server.HandshakeRequest
Return a reference to the HttpSession that the web socket handshake that started this conversation was part of, if the implementation is part of a Java EE web container.
getHttpSession() - Method in class org.glassfish.tyrus.core.RequestContext
 
getHttpStatus() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Gets the HTTP status for this response.
getHttpStatus(int) - Static method in class org.glassfish.grizzly.http.util.HttpStatus
 
getHttpStatusCode() - Method in exception org.glassfish.tyrus.core.HandshakeException
Get the error code.
getId() - Method in interface javax.websocket.Session
Returns a string containing the unique identifier assigned to this session.
getId() - Method in class org.glassfish.grizzly.http.util.TimeStamp
Each object can have an unique id, similar with name but providing faster access ( array vs.
getId() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getId() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getIdInternal() - Method in class org.glassfish.grizzly.http.server.Session
Return the session identifier for this session.
getIdleTimeoutInSeconds() - Method in class org.glassfish.grizzly.http.KeepAlive
 
getIndex() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the zero-relative index of our current parsing position within the string being parsed.
getIndex() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getIndexByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getIndexedAttributeAccessor() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
If AttributeHolder supports attribute access by index - it will return an IndexedAttributeAccessor, which will make Attribute access as fast as access to array element.
getIndexedAttributeAccessor() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Returns IndexedAttributeAccessor for accessing Attributes by index.
getInflater() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
getInfo() - Method in class org.glassfish.grizzly.http.server.Response
Return descriptive information about this Response implementation and the corresponding version number, in the format <description>/<version>.
getInitialBufferSize(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInitialClassLoader() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getInitialLimit(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInitialMessageSize() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getInitialMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getInitialPosition(int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getInputBuffer() - Method in class org.glassfish.grizzly.http.server.Request
 
getInputStream() - Method in class org.glassfish.grizzly.http.server.Request
Return the InputStream for this Request.
getInstalledExtensions() - Method in interface javax.websocket.WebSocketContainer
Return the set of Extensions installed in the container.
getInstalledExtensions() - Method in class org.glassfish.tyrus.client.ClientManager
 
getInstance(ByteChunk, String) - Static method in class org.glassfish.grizzly.http.util.C2BConverter
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.LeaderFollowerNIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
getInstance() - Static method in class org.glassfish.grizzly.strategies.WorkerThreadIOStrategy
 
getInstance(Class<T>, Session, ErrorCollector) - Method in class org.glassfish.tyrus.core.ComponentProviderService
Provide an instance of class which is coupled to Session.
getInstance() - Static method in class org.glassfish.tyrus.core.OsgiRegistry
Returns an OsgiRegistry instance.
getInstance(Class<T>, ErrorCollector) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Creates an instance of Class c using Class.newInstance().
getInstance(Class<T>) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Creates an instance of Class c using Class.newInstance().
getInt() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading an int value.
getInt(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading an int value.
getInt() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getInt() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getInt() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Convert the buffer to an int, cache the value
getInt() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getInt(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getInt() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getInt(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getInt() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getInt(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getInt() - Method in class org.glassfish.grizzly.utils.Holder.IntHolder
 
getInt() - Method in class org.glassfish.grizzly.utils.Holder.LazyIntHolder
 
getInterceptor() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
getInternalContext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the general Grizzly Context this filter context wraps.
getIntHeader(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the value of the specified header as an integer, or -1 if there is no such header for this request.
getIntHeader(Header) - Method in class org.glassfish.grizzly.http.server.Request
Return the value of the specified header as an integer, or -1 if there is no such header for this request.
getInvocableMethod(Method) - Method in class org.glassfish.tyrus.core.ComponentProvider
Get the method which should be invoked instead provided one.
getInvocableMethod(Method) - Method in class org.glassfish.tyrus.core.ComponentProviderService
 
getInvocableMethod(Method) - Method in class org.glassfish.tyrus.core.DefaultComponentProvider
 
getInvokeAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to process next Filter in chain.
getInvokeAction(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to process next Filter in chain.
getInvokeAction(E, Appender<E>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to process next Filter in chain.
getIoEvent() - Method in class org.glassfish.grizzly.Context
Get the processing IOEvent.
getIOEvents(int) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
getIOEvents(int) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
getIOStrategy() - Method in class org.glassfish.grizzly.AbstractTransport
Get the IOStrategy implementation, which will be used by Transport to process IOEvent.
getIOStrategy() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getIOStrategy() - Method in interface org.glassfish.grizzly.Transport
Get the IOStrategy implementation, which will be used by Transport to process IOEvent.
getJdkVersion() - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
getJmxEventListeners() - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
 
getJrouteId() - Method in class org.glassfish.grizzly.http.server.Request
Gets the jroute id of this request, which may have been sent as a separate JROUTE cookie or appended to the session identifier encoded in the URI (if cookies have been disabled).
getKeepAlive() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getKeepAliveTime(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Returns the max period of time a thread will wait for a new task to process.
getKernelThreadPool() - Method in class org.glassfish.grizzly.AbstractTransport
getKernelThreadPool() - Method in interface org.glassfish.grizzly.Transport
 
getKernelThreadPoolConfig() - Method in class org.glassfish.grizzly.AbstractTransport
getKernelThreadPoolConfig() - Method in interface org.glassfish.grizzly.Transport
 
getKey() - Method in interface org.glassfish.grizzly.localization.Localizable
Gets the key in the resource bundle.
getKey() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getKey() - Method in interface org.glassfish.tyrus.core.l10n.Localizable
Gets the key in the resource bundle.
getKey() - Method in class org.glassfish.tyrus.core.l10n.LocalizableMessage
 
getKeySize() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
Get the keysize.
getKeySize() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
Copied from org.apache.catalina.valves.CertificateValve
getLastAccessedTime() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
getLastResult(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
getLastResult() - Method in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
getLastResult(AttributeStorage) - Method in interface org.glassfish.grizzly.Transformer
Gets the last returned Transformer result.
getLastSelectedKeysCount() - Method in class org.glassfish.grizzly.nio.SelectorRunner
Number of SelectionKeys, which were selected last time.
getLazyCookieState() - Method in class org.glassfish.grizzly.http.Cookie
 
getLc() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getLength() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the length of the string we are parsing.
getLength() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
getLength() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns the length of the bytes.
getLength() - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns the length of the bytes.
getLength() - Method in interface org.glassfish.grizzly.http.util.Chunk
 
getLength() - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns the DataChunk length.
getLength() - Method in enum org.glassfish.grizzly.http.util.Header
Returns the length this header encoded using ISO-8859-1.
getLength() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns the length of the original buffer.
getLenToPosState(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
getLevel() - Method in class org.glassfish.grizzly.utils.LogFilter
 
getLimit() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getLimit() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
getLimit(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getLimit(Buffer) - Method in class org.glassfish.grizzly.memory.BufferArray
 
getLimit(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
getLinger() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getLinger() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getListener(String) - Method in class org.glassfish.grizzly.http.server.HttpServer
 
getListeners() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
getLocalAddr() - Method in class org.glassfish.grizzly.http.server.Request
Returns the Internet Protocol (IP) address of the interface on which the request was received.
getLocalAddress() - Method in interface org.glassfish.grizzly.Connection
Get the connection local address
getLocalAddress() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getLocalAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Returns the local address of this Connection, or null if it is unconnected.
getLocalAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Returns the local address of this Connection, or null if it is unconnected.
getLocale() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
getLocale() - Method in class org.glassfish.grizzly.http.server.Request
Return the preferred Locale that the client will accept content in, based on the value for the first Accept-Language header that was encountered.
getLocale() - Method in class org.glassfish.grizzly.http.server.Response
Return the Locale assigned to this response.
getLocale() - Method in class org.glassfish.grizzly.localization.Localizer
 
getLocale() - Method in class org.glassfish.tyrus.core.l10n.Localizer
 
getLocales() - Method in class org.glassfish.grizzly.http.server.Request
Return the set of preferred Locales that the client will accept content in, based on the values for any Accept-Language headers that were encountered.
getLocalHost() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getLocalName() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getLocalName() - Method in class org.glassfish.grizzly.http.server.Request
Returns the host name of the Internet Protocol (IP) interface on which the request was received.
getLocalPort() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getLocalPort() - Method in class org.glassfish.grizzly.http.server.Request
Returns the Internet Protocol (IP) port number of the interface on which the request was received.
getLogger() - Method in class org.glassfish.grizzly.utils.LogFilter
 
getLong() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a long value.
getLong(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a long value.
getLong() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getLong() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Convert the buffer to an long, cache the value
getLong() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getLong(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getLong() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getLong(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getLong() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getLong(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getLongAsBuffer(MemoryManager, long) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
getLower() - Method in class org.glassfish.grizzly.PortRange
 
getLowerCaseBytes() - Method in enum org.glassfish.grizzly.http.util.Header
Returns the lower-case byte representation of this header encoded using ISO-8859-1.
getLp() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getLTQInstance() - Static method in class org.glassfish.grizzly.utils.DataStructures
 
getLTQInstance(Class<T>) - Static method in class org.glassfish.grizzly.utils.DataStructures
 
getLzmaAliases() - Static method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
getMaintenance() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMajor() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMajorVersion() - Static method in class org.glassfish.grizzly.Grizzly
Get Grizzly framework major version
getMajorVersion() - Method in enum org.glassfish.grizzly.http.Protocol
 
getManagementObject(boolean) - Method in class org.glassfish.grizzly.http.server.HttpServer
 
getManager(String, ClassLoader) - Static method in class org.glassfish.grizzly.http.util.StringManager
Get the StringManager for a particular package.
getManager(ResourceBundle) - Static method in class org.glassfish.grizzly.http.util.StringManager
Get the StringManager for a particular package.
getManager(String, Locale, ClassLoader) - Static method in class org.glassfish.grizzly.http.util.StringManager
Get the StringManager for a particular package and Locale.
getMappedCacheSize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Return the size of Mapped memory used for caching
getMaskingKey() - Method in class org.glassfish.tyrus.core.frame.Frame
Get masking key.
getMatches(int[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
getMatchFinder() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getMatchLen(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getMatrixParameters() - Method in interface org.glassfish.tyrus.core.uri.internal.PathSegment
Get a map of the matrix parameters associated with the path segment.
getMaxAge() - Method in class org.glassfish.grizzly.http.Cookie
Returns the maximum age of the cookie, specified in seconds, By default, -1 indicating the cookie will persist until browser shutdown.
getMaxAsyncWriteQueueSize() - Method in interface org.glassfish.grizzly.Connection
Get the max size (in bytes) of asynchronous write queue associated with connection.
getMaxAsyncWriteQueueSize() - Method in class org.glassfish.grizzly.nio.NIOConnection
Get the max size (in bytes) of asynchronous write queue associated with connection.
getMaxAsyncWriteQueueSizeInBytes() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getMaxBinaryMessageBufferSize() - Method in interface javax.websocket.Session
The maximum length of incoming binary messages that this Session can buffer.
getMaxBinaryMessageBufferSize() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getMaxBinaryMessageBufferSize() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getMaxBufferedPostSize() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Gets the maximum POST body size, which can buffered in memory.
getMaxBufferedPostSize() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Gets the maximum POST body size, which can buffered in memory.
getMaxBufferSize() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
getMaxCacheEntries() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getMaxDispatchDepth() - Static method in class org.glassfish.grizzly.http.server.Request
 
getMaxEntrySize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getMaxFormPostSize() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Gets the maximum size of the POST body generated by an HTML form.
getMaxFormPostSize() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Gets the maximum size of the POST body generated by an HTML form.
getMaxHttpHeaderSize() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getMaxIdleTimeout() - Method in interface javax.websocket.Session
Return the number of milliseconds before this conversation may be closed by the container if it is inactive, i.e.
getMaxIdleTimeout() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getMaxIdleTimeout() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getMaxInactiveInterval() - Method in class org.glassfish.grizzly.http.util.TimeStamp
Inactive interval in millis - the time is computed in millis, convert to secs in the upper layer
getMaxLargeFileCacheSize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getMaxNumHeaders() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
getMaxPendingBytes() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getMaxPendingBytesPerConnection() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
 
getMaxPendingBytesPerConnection() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
getMaxPendingBytesPerConnection() - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
getMaxPoolSize() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getMaxQueueSize() - Method in interface org.glassfish.grizzly.asyncqueue.TaskQueue.MutableMaxQueueSize
 
getMaxReentrants() - Static method in class org.glassfish.grizzly.Writer.Reentrant
Returns the maximum number of write() method reentrants a thread is allowed to made.
getMaxRequestHeaders() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Returns the maximum number of headers allowed for a request.
getMaxRequestParameters() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Returns the maximum number of parameters allowed per request.
getMaxRequestsCount() - Method in class org.glassfish.grizzly.http.KeepAlive
 
getMaxResponseHeaders() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Returns the maximum number of headers allowed for a response.
getMaxSmallBufferSize() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
getMaxSmallFileCacheSize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getMaxTextMessageBufferSize() - Method in interface javax.websocket.Session
The maximum length of incoming text messages that this Session can buffer.
getMaxTextMessageBufferSize() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getMaxTextMessageBufferSize() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getMemoryConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the memory monitoring config.
getMemoryManager() - Method in class org.glassfish.grizzly.AbstractTransformer
 
getMemoryManager() - Method in class org.glassfish.grizzly.AbstractTransport
Get the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
getMemoryManager() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getMemoryManager() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getMemoryManager() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
A simple alias for FilterChainContext.getConnection().getTransport().getMemoryManager().
getMemoryManager() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getMemoryManager() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getMemoryManager() - Method in interface org.glassfish.grizzly.Transport
Get the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
getMemoryPool() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getMessage() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
getMessage() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get message object, associated with the current processing.
getMessage() - Method in class org.glassfish.grizzly.http.server.Response
Return the error message that was set with sendError() for this Response.
getMessage(String, Object...) - Method in class org.glassfish.grizzly.localization.LocalizableMessageFactory
 
getMessage() - Method in class org.glassfish.grizzly.ReadResult
Get the message, which was read.
getMessage() - Method in class org.glassfish.grizzly.TransformationResult
 
getMessage() - Method in class org.glassfish.grizzly.WriteResult
Get the message, which was read.
getMessage(String, Object...) - Method in class org.glassfish.tyrus.core.l10n.LocalizableMessageFactory
 
getMessageCloner() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
getMessageHandlers() - Method in interface javax.websocket.Session
Return an unmodifiable copy of the set of MessageHandlers for this Session.
getMessageHandlers() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Not supported (yet?).
getMessageHandlers() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getMethod() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Get the HTTP request method.
getMethod() - Method in class org.glassfish.grizzly.http.server.Request
Return the HTTP request method used in this Request.
getMethodBytes() - Method in class org.glassfish.grizzly.http.Method
 
getMethodDC() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Get the HTTP request method as DataChunk (avoiding creation of a String object).
getMethodString() - Method in class org.glassfish.grizzly.http.Method
 
getMimeType() - Method in class org.glassfish.grizzly.http.util.ContentType
Returns the mime-type part of the content-type (the part without charset attribute).
getMinEntrySize() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getMinor() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getMinorVersion() - Static method in class org.glassfish.grizzly.Grizzly
Get Grizzly framework minor version
getMinorVersion() - Method in enum org.glassfish.grizzly.http.Protocol
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the Transport monitoring configuration MonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.Connection
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.http.KeepAlive
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Get the web server monitoring config.
getMonitoringConfig() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
getMonitoringConfig() - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.monitoring.MonitoringAware
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.nio.NIOConnection
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
Return the object associated MonitoringConfig.
getMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the Transport monitoring configuration MonitoringConfig.
getMonitoringProbes() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Get the ConnectionProbe, which are registered on the Connection.
getName() - Method in interface javax.websocket.Extension
The name of the extension.
getName() - Method in interface javax.websocket.Extension.Parameter
Return the name of the extension parameter.
getName() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the Transport name.
getName() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
getName() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
getName() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
Get the Transformer name.
getName() - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
Get the Transformer name.
getName() - Method in interface org.glassfish.grizzly.http.ContentEncoding
Get the ContentEncoding name.
getName() - Method in class org.glassfish.grizzly.http.Cookie
Returns the name of the cookie.
getName() - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
getName() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getName() - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
getName() - Method in class org.glassfish.grizzly.http.server.GrizzlyPrincipal
 
getName() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Get the HttpHandler name.
getName() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getName() - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
 
getName(int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Returns the Nth header name, or null if there is no such header.
getName() - Method in class org.glassfish.grizzly.http.util.TimeStamp
Return the "name" of the timestamp.
getName() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getName() - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
getName() - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
getName() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getName() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getName() - Method in interface org.glassfish.grizzly.Transformer
Get the Transformer name.
getName() - Method in interface org.glassfish.grizzly.Transport
Gets the Transport name.
getName() - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
getName() - Method in class org.glassfish.grizzly.utils.StringDecoder
 
getName() - Method in class org.glassfish.grizzly.utils.StringEncoder
 
getName() - Method in class org.glassfish.tyrus.core.TyrusExtension
 
getName() - Method in class org.glassfish.tyrus.core.TyrusExtension.TyrusParameter
 
getNamePrefix() - Method in class org.glassfish.grizzly.AbstractTransformer
 
getNames() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the list of template names.
getNameToPattern() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the map of template names to patterns.
getNegotiatedExtensions(List<Extension>, List<Extension>) - Method in class javax.websocket.server.ServerEndpointConfig.Configurator
Return the ordered list of extensions that t server endpoint will support given the requested extension list passed in, the empty list if none.
getNegotiatedExtensions() - Method in interface javax.websocket.Session
Return the list of extensions currently in use for this conversation.
getNegotiatedExtensions() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getNegotiatedExtensions(List<Extension>) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Server-side; Get the negotiated extensions' names based on the extensions supported by client.
getNegotiatedExtensions() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getNegotiatedProtocol(List<String>) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Server-side; Compute the sub-protocol which will be used.
getNegotiatedSubprotocol(List<String>, List<String>) - Method in class javax.websocket.server.ServerEndpointConfig.Configurator
Return the subprotocol the server endpoint has chosen from the requested list supplied by a client who wishes to connect, or none if there wasn't one this server endpoint liked.
getNegotiatedSubprotocol() - Method in interface javax.websocket.Session
Return the sub protocol agreed during the websocket handshake for this conversation.
getNegotiatedSubprotocol() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getNegotiatedSubprotocol() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getNetBufferSize() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
getNewConnectionFilterChain() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
getNextFilter(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
getNextUnusedCookie() - Method in class org.glassfish.grizzly.http.Cookies
 
getNIOChannelDistributor() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getNIOChannelDistributor() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getNIOInputStream() - Method in class org.glassfish.grizzly.http.server.Request
Return the NIOInputStream for this Request.
getNIOOutputStream() - Method in class org.glassfish.grizzly.http.server.Response
Return the NIOOutputStream associated with this Response.
getNIOReader() - Method in class org.glassfish.grizzly.http.server.Request
Returns the NIOReader associated with this Request.
getNIOWriter() - Method in class org.glassfish.grizzly.http.server.Response
Return the NIOWriter associated with this Response.
getNoCompressionUserAgents() - Method in class org.glassfish.grizzly.http.CompressionConfig
Returns the read-only set of the user-agents, which will be always responded with uncompressed are.
getNoCompressionUserAgents() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().getNoCompressionUserAgents()
getNormalizedTemplate() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the normalized template.
getNote(Note<E>) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the Note value associated with this Request, or null if no such binding exists.
getNote(Note<E>) - Method in class org.glassfish.grizzly.http.server.Request
Return the Note value associated with this Request, or null if no such binding exists.
getNoteNames() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return a Set containing the String names of all note bindings that exist for this request.
getNoteNames() - Method in class org.glassfish.grizzly.http.server.Request
Return a Set containing the String names of all note bindings that exist for this request.
getNumAvailableBytes() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
getNumberOfExplicitCharacters() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the number of characters in the regular expression not resulting from conversion of template variables.
getNumberOfExplicitRegexes() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the number of explicit regexes declared in template variables.
getNumberOfExplicitRegexes() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the number of explicit regular expressions.
getNumberOfLiteralCharacters() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the number of literal characters.
getNumberOfTemplateVariables() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the number of template variables.
getNumFastBytes() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getObject() - Method in exception javax.websocket.EncodeException
Return the Object that could not be encoded.
getOffset() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
getOpcode() - Method in class org.glassfish.tyrus.core.frame.Frame
Get opcode.
getOpenSessions() - Method in interface javax.websocket.Session
Return a copy of the Set of all the open web socket sessions that represent connections to the same endpoint to which this session represents a connection.
getOpenSessions() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Not supported.
getOpenSessions(TyrusSession) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Get the endpoint's open Sessions.
getOpenSessions() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getOriginalRequestURIBC() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getOsgiRegistryInstance() - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Returns an OsgiRegistry instance.
getOutputBuffer() - Method in class org.glassfish.grizzly.http.server.Response
 
getOutputSink() - Method in class org.glassfish.grizzly.http.HttpContext
 
getOutputStream() - Method in class org.glassfish.grizzly.http.server.Response
Return the OutputStream associated with this Response.
getPackageResources(String, ClassLoader) - Method in class org.glassfish.tyrus.core.OsgiRegistry
 
getParameter(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the value of the specified request parameter, if any; otherwise, return null.
getParameter(String) - Method in class org.glassfish.grizzly.http.util.Parameters
 
getParameterizedClassArguments(ReflectionHelper.DeclaringClassInterfacePair) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the parameterized class arguments for a declaring class that declares a generic interface type.
getParameterizedTypeArguments(ReflectionHelper.DeclaringClassInterfacePair) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the parameterized type arguments for a declaring class that declares a generic interface type.
getParameterMap() - Method in interface javax.websocket.server.HandshakeRequest
Return the request parameters associated with the request.
getParameterMap() - Method in class org.glassfish.grizzly.http.server.Request
Returns a Map of the parameters of this request.
getParameterMap() - Method in class org.glassfish.tyrus.core.RequestContext
 
getParameterNames() - Method in class org.glassfish.grizzly.http.server.Request
Return the names of all defined request parameters for this request.
getParameterNames() - Method in class org.glassfish.grizzly.http.util.Parameters
 
getParameterNames() - Method in class org.glassfish.tyrus.core.uri.Match
Get parameter names.
getParameters() - Method in interface javax.websocket.Extension
The extension parameters for this extension in the order they appear in the http headers.
getParameters() - Method in class org.glassfish.grizzly.http.server.Request
Returns the low-level parameters holder for finer control over parameters.
getParameters() - Method in class org.glassfish.tyrus.core.TyrusExtension
 
getParameterValue(String) - Method in class org.glassfish.tyrus.core.uri.Match
Get value of given parameter.
getParameterValues(String) - Method in class org.glassfish.grizzly.http.server.Request
Return the defined values for the specified request parameter, if any; otherwise, return null.
getParameterValues(String) - Method in class org.glassfish.grizzly.http.util.Parameters
 
getParent() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
getPath() - Method in interface javax.websocket.server.ServerEndpointConfig
Return the path for this endpoint configuration.
getPath() - Method in class org.glassfish.grizzly.http.Cookie
Returns the path on the server to which the browser returns this cookie.
getPath() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getPath() - Method in interface org.glassfish.tyrus.core.uri.internal.PathSegment
Get the path segment.
getPath() - Method in class org.glassfish.tyrus.core.uri.Match
Get path.
getPathInfo() - Method in class org.glassfish.grizzly.http.server.Request
Returns any extra path information associated with the URL the client sent when it made this request.
getPathParameters() - Method in interface javax.websocket.Session
Return a map of the path parameter names and values used associated with the request this session was opened under.
getPathParameters() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getPathParameters() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getPattern() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the URI pattern.
getPattern() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the pattern.
getPayloadData() - Method in class org.glassfish.tyrus.core.frame.Frame
Get payload data.
getPayloadExpectation() - Method in class org.glassfish.grizzly.http.Method
 
getPayloadLength() - Method in class org.glassfish.tyrus.core.frame.Frame
Get payload length.
getPb() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
getPeerAddress() - Method in interface org.glassfish.grizzly.Connection
Get the connection peer address
getPeerAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getPeerAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Returns the address of the endpoint this Connection is connected to, or null if it is unconnected.
getPeerCertificateChain(SSLConnectionContext, FilterChainContext, boolean) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
Obtains the certificate chain for this SSL session.
getPeerCertificateChain() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The client certificate chain (if any).
getPeerCertificateChain(boolean) - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The client certificate chain (if any).
getPeerCertificateChain() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getPeerCertificateChain(boolean) - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getPendingTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getPoolName() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getPort() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getPort() - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
getPortRange() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getPosition(E) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
getPosition(Buffer) - Method in class org.glassfish.grizzly.memory.BufferArray
 
getPosition(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
getPostBody(int) - Method in class org.glassfish.grizzly.http.server.Request
Gets the POST body of this request.
getPostponedTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getPreferredSubprotocols() - Method in interface javax.websocket.ClientEndpointConfig
Return the ordered list of sub protocols a client endpoint would like to use, in order of preference, favorite first that this client would like to use for its sessions.
getPreviousFilter(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
getPrice(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
getPrice(int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPrice0(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPrice1(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getPriority() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getProbes() - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Get the the monitoring probes, which are registered on the objet.
getProbes() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Get the the monitoring probes, which are registered on the objet.
getProbesUnsafe() - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Get the monitoring probes array (direct).
getProcessedSizeAdd() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
getProcessingState() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getProcessor() - Method in class org.glassfish.grizzly.AbstractBindingHandler
Get the default Processor to process IOEvent, occurring on connection phase.
getProcessor() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Get the default Processor to process IOEvent, occurring on connection phase.
getProcessor() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
getProcessor() - Method in interface org.glassfish.grizzly.Connection
Gets the default Processor, which will process Connection I/O events.
getProcessor() - Method in class org.glassfish.grizzly.Context
Get the Processor, which is responsible to process the IOEvent.
getProcessor() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getProcessor() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
getProcessor() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
getProcessor() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getProcessor() - Method in interface org.glassfish.grizzly.Transport
Gets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
getProcessorSelector() - Method in class org.glassfish.grizzly.AbstractBindingHandler
Gets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
getProcessorSelector() - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Gets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
getProcessorSelector() - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
getProcessorSelector() - Method in interface org.glassfish.grizzly.Connection
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Connection's Processor is null.
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
getProcessorSelector() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
getProcessorSelector() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getProcessorSelector() - Method in interface org.glassfish.grizzly.Transport
Gets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
getProperties() - Method in class org.glassfish.tyrus.client.ClientManager
Container properties.
getProperties() - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension.ExtensionContext
Mutable, not synchronised property map.
getProperty(Map<String, Object>, String, Class<T>) - Static method in class org.glassfish.tyrus.core.Utils
Get typed property from generic property map.
getProtocol() - Method in class org.glassfish.grizzly.http.HttpHeader
Get HTTP protocol version.
getProtocol() - Method in class org.glassfish.grizzly.http.server.Request
Return the protocol and version used to make this Request.
getProtocolBytes() - Method in enum org.glassfish.grizzly.http.Protocol
 
getProtocolDC() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the HTTP message protocol version as DataChunk (avoiding creation of a String object).
getProtocolString() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the HTTP message protocol version.
getProtocolString() - Method in enum org.glassfish.grizzly.http.Protocol
 
getProtocolVersion() - Method in interface javax.websocket.Session
Returns the version of the websocket protocol currently being used.
getProtocolVersion() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getProtocolVersion() - Method in class org.glassfish.tyrus.core.TyrusSession
Web Socket protocol version used.
getPushBackHandler() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
Deprecated.
getPushBackHandler() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
The PushBackHandler passed along with one of the Writer's write(...) method call.
getPushBackHandler() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
Deprecated.
getQueryString() - Method in interface javax.websocket.server.HandshakeRequest
Return the query string associated with the request.
getQueryString() - Method in interface javax.websocket.Session
Return the query string associated with the request this session was opened under.
getQueryString() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns the query string that is contained in the request URL after the path.
getQueryString() - Method in class org.glassfish.grizzly.http.server.Request
Return the query string associated with this request.
getQueryString() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getQueryString() - Method in class org.glassfish.tyrus.core.RequestContext
 
getQueryString() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getQueryStringDC() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns the query string that is contained in the request URL after the path.
getQueryStringEncoding() - Method in class org.glassfish.grizzly.http.util.Parameters
 
getQueue() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Get the queue of tasks, which will be processed asynchronously
getQueue() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
getQueue() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getQueueLimit() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getQuotedValueEndPosition(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given a starting position after an initial quote character, this gets the position of the end quote.
getQuotedValueEndPosition(byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given a starting position after an initial quote character, this gets the position of the end quote.
getQuotedValueEndPosition(String, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given a starting position after an initial quote character, this gets the position of the end quote.
getRawCookies() - Method in class org.glassfish.grizzly.http.server.Request
TODO DOCS
getReadBufferSize() - Method in class org.glassfish.grizzly.AbstractTransport
Get the default size of Buffers, which will be allocated for reading data from Transport's Connections.
getReadBufferSize() - Method in interface org.glassfish.grizzly.Connection
Get the default size of Buffers, which will be allocated for reading data from Connection.
getReadBufferSize() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Get the default size of Buffers, which will be allocated for reading data from Connection.
getReadBufferSize() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
getReadBufferSize() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Get the default size of Buffers, which will be allocated for reading data from Connection.
getReadBufferSize() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getReadBufferSize() - Method in interface org.glassfish.grizzly.Transport
Get the default size of Buffers, which will be allocated for reading data from Transport's Connections.
getReader() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.ImmutableAsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
Get AsyncQueueReader implementation.
getReader() - Method in class org.glassfish.grizzly.http.server.Request
Returns the Reader associated with this Request.
getReader() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getReader(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Reader implementation, depending on the requested mode.
getReader(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Reader implementation, depending on the requested mode.
getReader(Connection) - Method in interface org.glassfish.grizzly.Transport
Get the Reader to read data from the Connection.
getReader(boolean) - Method in interface org.glassfish.grizzly.Transport
Get the Reader implementation, depending on the requested mode.
getReadHandler() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
getReadHandler() - Method in interface org.glassfish.tyrus.spi.Connection
Returns a read handler.
getReadSize() - Method in class org.glassfish.grizzly.ReadResult
Get the number of bytes, which were read.
getReadTimeout(TimeUnit) - Method in class org.glassfish.grizzly.AbstractTransport
Returns the current value for the blocking read timeout converted to the provided TimeUnit specification.
getReadTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Connection
Returns the current value for the blocking read timeout converted to the provided TimeUnit specification.
getReadTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getReadTimeout(TimeUnit) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getReadTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Transport
Returns the current value for the blocking read timeout converted to the provided TimeUnit specification.
getReadyThreadBufferSize() - Method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Get the size of local thread memory pool.
getReasonPhrase() - Method in class javax.websocket.CloseReason
The reason phrase associated with this CloseReason.
getReasonPhrase() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Gets the status reason phrase for this response.
getReasonPhrase() - Method in class org.glassfish.grizzly.http.util.HttpStatus
 
getReasonPhrase() - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
Get HTTP reason phrase.
getReasonPhraseBytes() - Method in class org.glassfish.grizzly.http.util.HttpStatus
 
getReasonPhraseDC() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Gets the status reason phrase for this response as DataChunk (avoid creation of a String object}.
getReasonPhraseRawDC() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Gets the custom status reason phrase for this response as DataChunk (avoid creation of a String object}.
getRegex() - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Get the regular expression.
getRelativeURI(Request) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
getRemainder() - Method in class org.glassfish.tyrus.core.frame.TextFrame
Remainder after UTF-8 decoding.
getRemainderBuffer() - Method in class org.glassfish.grizzly.http.ParsingResult
 
getRemainingArray(ByteBuffer) - Static method in class org.glassfish.tyrus.core.Utils
Creates the array of bytes containing the bytes from the position to the limit of the ByteBuffer.
getRemoteAddr() - Method in class org.glassfish.grizzly.http.server.Request
Return the remote IP address making this Request.
getRemoteAddress() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getRemoteHost() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getRemoteHost() - Method in class org.glassfish.grizzly.http.server.Request
Return the remote host name making this Request.
getRemotePort() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getRemotePort() - Method in class org.glassfish.grizzly.http.server.Request
Returns the Internet Protocol (IP) source port of the client or last proxy that sent the request.
getRemoteSessionIds(String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Get set containing session ids of all remote sessions registered to given endpoint path.
getRemoteUser() - Method in class org.glassfish.grizzly.http.server.Request
Return the name of the remote user that has been authenticated for this Request.
getRequest() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
getRequest() - Method in class org.glassfish.grizzly.http.server.Request
 
getRequest() - Method in class org.glassfish.grizzly.http.server.Response
Return the Request with which this Response is associated.
getRequest() - Method in class org.glassfish.tyrus.core.Handshake
Client side only - get the UpgradeRequest.
getRequestedSessionId() - Method in class org.glassfish.grizzly.http.server.Request
Return the session identifier included in this request, if any.
getRequestExecutor() - Method in class org.glassfish.grizzly.http.server.Request
 
getRequestExecutorProvider() - Method in class org.glassfish.grizzly.http.server.HttpHandler
 
getRequestParameterMap() - Method in interface javax.websocket.Session
Return the request parameters associated with the request this session was opened under.
getRequestParameterMap() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getRequestParameterMap() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getRequestURI() - Method in interface javax.websocket.server.HandshakeRequest
Return the request URI of the handshake request.
getRequestURI() - Method in interface javax.websocket.Session
Return the URI under which this session was opened, including the query string if there is one.
getRequestURI() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns the request URL.
getRequestURI() - Method in class org.glassfish.grizzly.http.server.Request
Return the request URI for this request.
getRequestURI() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getRequestURI() - Method in class org.glassfish.tyrus.core.RequestContext
 
getRequestUri() - Method in class org.glassfish.tyrus.core.RequestContext
 
getRequestURI() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getRequestUri() - Method in class org.glassfish.tyrus.spi.UpgradeRequest
Get the undecoded request uri (up to the query string) of underlying HTTP handshake request.
getRequestURIBC() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getRequestURIEncoding() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Get the request URI encoding used by this HttpHandler.
getRequestURIRef() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns the request URL of the HTTP request as RequestURIRef (avoiding creation of a String object).
getRequestURL() - Method in class org.glassfish.grizzly.http.server.Request
Reconstructs the URL the client used to make the request.
getRerunFilterAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction, which instructs FilterChain to rerun the filter.
getResolver() - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
getResourceBundle(String) - Method in class org.glassfish.tyrus.core.OsgiRegistry
Tries to load resource bundle via OSGi means.
getResourceBundleName() - Method in interface org.glassfish.grizzly.localization.Localizable
 
getResourceBundleName() - Method in class org.glassfish.grizzly.localization.LocalizableMessage
 
getResourceBundleName() - Method in interface org.glassfish.tyrus.core.l10n.Localizable
Get the name of the localization messages resource bundle.
getResourceBundleName() - Method in class org.glassfish.tyrus.core.l10n.LocalizableMessage
 
getResources() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the proxied resources of this AlternateDocBase.
getResponse() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getResponse() - Method in class org.glassfish.grizzly.http.server.Request
 
getResponse() - Method in class org.glassfish.grizzly.http.server.Response
getRestrictedUserAgents() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getResult() - Method in interface org.glassfish.grizzly.impl.FutureImpl
Get current result value without any blocking.
getResult() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Get current result value without any blocking.
getResult() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
getResult() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Get current result value without any blocking.
getRunnable() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getRunnerThread() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getScheduledExecutorService() - Method in class org.glassfish.tyrus.core.BaseContainer
 
getScheduledExecutorService() - Method in class org.glassfish.tyrus.core.ExecutorServiceProvider
getScheme() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Get the HTTP request scheme, which if non-null overrides default one picked up by framework during runtime.
getScheme() - Method in class org.glassfish.grizzly.http.server.Request
Return the scheme used to make this Request.
getScheme() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Get the HTTP request scheme, which if non-null overrides default one picked up by framework during runtime.
getSecond() - Method in class org.glassfish.grizzly.utils.Pair
 
getSecondsMaxAge() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
getSecure() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getSelectionKey() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getSelectionKey() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getSelectionKeyHandler() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectionKeyHandler() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectionKeyInterest() - Method in enum org.glassfish.grizzly.IOEvent
 
getSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getSelectorHandler() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorHandler() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectorPool() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getSelectorProvider() - Method in class org.glassfish.grizzly.nio.NIOTransport
Get the SelectorProvider to be used by this transport.
getSelectorProvider() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
getSelectorProvider() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectorRunner() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getSelectorRunner() - Method in class org.glassfish.grizzly.nio.RegisterChannelResult
 
getSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorRunnersCount() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getSelectorThreadPoolConfig() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getSelectTimeout() - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
getSelectTimeout() - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
getSendStream() - Method in interface javax.websocket.RemoteEndpoint.Basic
Opens an output stream on which a binary message may be sent.
getSendTimeout() - Method in interface javax.websocket.RemoteEndpoint.Async
Return the number of milliseconds the implementation will timeout attempting to send a websocket message.
getSendWriter() - Method in interface javax.websocket.RemoteEndpoint.Basic
Opens an character stream on which a text message may be sent.
getServerConfiguration() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
getServerConnectionBackLog() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the default server connection backlog size.
getServerConnectionBackLog() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getServerName() - Method in class org.glassfish.grizzly.http.server.Request
Return the server name responding to this Request.
getServerPort() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
getServerPort() - Method in class org.glassfish.grizzly.http.server.Request
Return the server port responding to this Request.
getServerSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getServerSocketSoTimeout() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getServerSSLEngineConfig() - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
getSession() - Method in exception javax.websocket.SessionException
Return the Session on which the problem occurred.
getSession() - Method in class org.glassfish.grizzly.http.server.Request
Return the session associated with this Request, creating one if necessary.
getSession(boolean) - Method in class org.glassfish.grizzly.http.server.Request
Return the session associated with this Request, creating one if necessary and requested.
getSessionId() - Method in interface org.glassfish.grizzly.ssl.SSLSupport
The current session Id.
getSessionId() - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
getSessionTimeout() - Method in class org.glassfish.grizzly.http.server.Session
Return a long representing the maximum idle time (in milliseconds) a session can be.
getShort() - Method in interface org.glassfish.grizzly.Buffer
Relative get method for reading a short value.
getShort(int) - Method in interface org.glassfish.grizzly.Buffer
Absolute get method for reading a short value.
getShort() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getShort(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
getShort() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getShort(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
getShort() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getShort(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
getSize() - Method in class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
getSource() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader
 
getSrc() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
getSrc() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
getSrcAddress() - Method in class org.glassfish.grizzly.ReadResult
Get the source address, the message was read from.
getSrcAddressHolder() - Method in class org.glassfish.grizzly.ReadResult
Get the source address, the message was read from.
getSslConnectionContext(Connection) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
getSslContext() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
getSslEngine() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
getSSLEngine(Connection) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
getSslEngineConfig() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getSSLPacketSize(Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
getStackTrace() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
getStackTraceAsString(Throwable) - Static method in class org.glassfish.grizzly.utils.Exceptions
Returns the Throwable's stack trace information as String.
getStart() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
getStart() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns the start offset of the bytes.
getStart() - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns the start offset of the bytes.
getStart() - Method in interface org.glassfish.grizzly.http.util.Chunk
 
getStart() - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns the DataChunk start position.
getStartIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
getState() - Method in class org.glassfish.grizzly.AbstractTransport
Return the Transport state controller.
getState() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getState() - Method in interface org.glassfish.grizzly.Transport
Return the Transport state controller.
getState() - Method in class org.glassfish.grizzly.utils.StateHolder
Gets current state Current StateHolder locking mode will be used
getStateLocker() - Method in class org.glassfish.grizzly.utils.StateHolder
Gets Read/Write locker, which is used by this StateHolder
getStatus() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Gets the status code for this response.
getStatus() - Method in class org.glassfish.grizzly.http.server.Response
Return the HTTP status code associated with this Response.
getStatus() - Method in class org.glassfish.grizzly.ProcessorResult
Get the result status.
getStatus() - Method in class org.glassfish.grizzly.TransformationResult
 
getStatus() - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
Get HTTP status.
getStatus() - Method in class org.glassfish.tyrus.spi.UpgradeResponse
Gets the current HTTP status code of this response.
getStatus() - Method in interface org.glassfish.tyrus.spi.WebSocketEngine.UpgradeInfo
Returns the status of HTTP request upgrade.
getStatusBytes() - Method in class org.glassfish.grizzly.http.util.HttpStatus
 
getStatusCode() - Method in class org.glassfish.grizzly.http.util.HttpStatus
 
getStopAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain to stop executing phase.
getStopAction(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain stop executing phase.
getStopAction(E, Appender<E>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction implementation, which instructs FilterChain stop executing phase.
getStreamReader(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
Get the Connection StreamReader, to read data from the Connection.
getStreamWriter(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
Get the Connection StreamWriter, to write data to the Connection.
getString() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Return the String we are currently parsing.
getString() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns the string value.
getString(String) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle or return null if the String is not found.
getString(String, Object[]) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle and format it with the given set of arguments.
getString(String, Object) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle and format it with the given object argument.
getString(String, Object, Object) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle and format it with the given object arguments.
getString(String, Object, Object, Object) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle and format it with the given object arguments.
getString(String, Object, Object, Object, Object) - Method in class org.glassfish.grizzly.http.util.StringManager
Get a string from the underlying resource bundle and format it with the given object arguments.
getStringConstructor(Class) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the constructor that has a single parameter of String.
getStringList(List<T>, Utils.Stringifier<T>) - Static method in class org.glassfish.tyrus.core.Utils
Get list of strings from List<T>.
getSubprotocols() - Method in interface javax.websocket.server.ServerEndpointConfig
Return the websocket subprotocols configured.
getSupportedWireProtocolVersions() - Static method in enum org.glassfish.tyrus.core.Version
 
getSuspendAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get NextAction, which instructs FilterChain to suspend filter chain execution.
getSuspendContext() - Method in class org.glassfish.grizzly.http.server.Response
Get the context of the suspended Response.
getSuspendingStopAction() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
getSuspendStatus() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
getSyncConnectTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
getSyncConnectTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
getSystemInheritedChannel(Class<?>) - Method in class org.glassfish.grizzly.AbstractBindingHandler
 
getTask() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
getTask() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool.SyncThreadWorker
 
getTempHeaderEncodingBuffer() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getTemplate() - Method in class org.glassfish.tyrus.core.uri.internal.PathPattern
 
getTemplate() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the URI template as a String.
getTemplate() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Get the template.
getTemplateVariables() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Get the list of template variables for the template.
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
getTemporarySelectorIO() - Method in interface org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorsEnabledTransport
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getTemporarySelectorIO() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getText() - Method in exception javax.websocket.DecodeException
Return the encoded string that is either the whole message, or the partial message that could not be decoded, or null if this exception arose from a failure to decode a binary message..
getTextPayload() - Method in class org.glassfish.tyrus.core.frame.TextFrame
Get text payload.
getThis() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
getThis() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
getThis() - Method in class org.glassfish.grizzly.NIOTransportBuilder
getThread() - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getThread() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getThreadFactory() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Returns ThreadFactory.
getThreadLocalPool() - Static method in class org.glassfish.grizzly.memory.AbstractMemoryManager
Get thread associated buffer pool.
getThreadName() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
getThreadPool() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
getThreadPool() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
getThreadPool() - Method in class org.glassfish.grizzly.http.server.io.ServerInputBuffer
 
getThreadPool() - Method in class org.glassfish.grizzly.http.server.io.ServerOutputBuffer
 
getThreadPool() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
getThreadPoolConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the thread pool monitoring config.
getThreadPoolFor(Connection, IOEvent) - Method in interface org.glassfish.grizzly.IOStrategy
Returns an Executor to be used to run given ioEvent processing for the given connection.
getThreadPoolFor(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
getThreadPoolFor(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.SameThreadIOStrategy
 
getThreadPoolFor(Connection, IOEvent) - Method in class org.glassfish.grizzly.strategies.SimpleDynamicNIOStrategy
 
getThreadPoolMonitoringConfig() - Method in class org.glassfish.grizzly.AbstractTransport
Get the monitoring configuration for Transport thread pool.
getThreadPoolMonitoringConfig() - Method in interface org.glassfish.grizzly.Transport
Get the monitoring configuration for Transport thread pool.
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
getTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.http.server.SuspendContext
Get the suspended Response timeout.
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Get the timeout for StreamWriter I/O operations.
getTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Get the timeout for StreamWriter I/O operations.
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
getTimeout(FilterChainContext) - Method in interface org.glassfish.grizzly.utils.IdleTimeoutFilter.TimeoutResolver
 
getTimeout(TimeUnit) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
getTimeoutHandler() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
getTimeoutHandler() - Method in interface org.glassfish.grizzly.http.server.SuspendContext
Get the suspended Response TimeoutHandler.
getTimeoutHandler() - Method in class org.glassfish.tyrus.client.TyrusClientEngine
Get TimeoutHandler associated with current ClientEngine instance.
getTimeoutMillis(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
getTimestamp() - Method in class org.glassfish.grizzly.http.server.Session
 
getTokenEndPosition(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given the starting position of a token, this gets the end of the token, with no separator characters in between.
getTokenEndPosition(Buffer, int, int, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
getTokenEndPosition(byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given the starting position of a token, this gets the end of the token, with no separator characters in between.
getTokenEndPosition(byte[], int, int, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
getTokenEndPosition(String, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Given the starting position of a token, this gets the end of the token, with no separator characters in between.
getTokenEndPosition(String, int, int, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
getTrainThreshold() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
getTransactionMonitor() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getTransactionTimeout() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getTransactionTimeout(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
getTransactionTimeout(TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
getTransactionTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
getTransferEncoding() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the TransferEncoding, responsible for the parsing/serialization of the HTTP message content
getTransferEncodings() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Gets registered TransferEncodings.
getTransport() - Method in interface org.glassfish.grizzly.Connection
Get the Transport, to which this Connection belongs to.
getTransport() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getTransport() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getTransport() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
getTransport() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
getTransport() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
getTransport() - Method in interface org.glassfish.grizzly.ShutdownContext
 
getTransportConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the transport monitoring config.
getTransportContext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the TransportFilter related context.
getTransportFilter() - Method in interface org.glassfish.grizzly.filterchain.FilterChainEnabledTransport
Get transport Filter, which is aware of Transport specifics; knows how to read/write from/to Transport specific Connection streams.
getTransportFilter() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
getTransportFilter() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
getTransportFilter0(Transport) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Get default Transport specific transport filter.
getTransportSelectorRunners() - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
getType() - Method in class org.glassfish.grizzly.CloseReason
Return information whether Connection was closed locally or remotely.
getType() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
getType() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Return the type of the original content.
getType() - Method in class org.glassfish.tyrus.core.coder.CoderWrapper
Get the return type of the encode / decode method.
getTypeArgumentAndClass(Type) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
 
getUpdate() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
getUpgrade() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getUpgradeDC() - Method in class org.glassfish.grizzly.http.HttpHeader
 
getUploadTimeout() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getUpper() - Method in class org.glassfish.grizzly.PortRange
 
getUri() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
getUri() - Method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
getURI() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getURI(Charset) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
getUriEncoding() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
getUrlPattern() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the url pattern of this AlternateDocBase.
getUrlPatternSlashCount() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the number of slashes in the url pattern of this AlternateDocBase.
getUrlPatternSuffix() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the extension suffix of the url pattern of this AlternateDocBase.
getUrlPatternType() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the url pattern type (exact, wildcard, extension) of this AlternateDocBase.
getUrlPatternWildcardPath() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the wildcard path of this AlternateDocBase (this is the path specified by the wildcard pattern, minus the trailing '*').
getUserPrincipal() - Method in interface javax.websocket.server.HandshakeRequest
Return the authenticated user or null if no user is authenticated for this handshake.
getUserPrincipal() - Method in interface javax.websocket.Session
Return the authenticated user for this Session or null if no user is authenticated for this session.
getUserPrincipal() - Method in class org.glassfish.grizzly.http.server.Request
Return the principal that has been authenticated for this Request.
getUserPrincipal() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getUserPrincipal() - Method in class org.glassfish.tyrus.core.RequestContext
 
getUserPrincipal() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getUserProperties() - Method in interface javax.websocket.EndpointConfig
This method returns a modifiable Map that the developer may use to store application specific information relating to the endpoint that uses this configuration instance.
getUserProperties() - Method in interface javax.websocket.Session
While the session is open, this method returns a Map that the developer may use to store application specific information relating to this session instance.
getUserProperties() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
getUserProperties() - Method in class org.glassfish.tyrus.core.TyrusSession
 
getValue() - Method in interface javax.websocket.Extension.Parameter
Return the value of the extension parameter.
getValue(AttributeStorage, Attribute<T>, T) - Static method in class org.glassfish.grizzly.AbstractTransformer
 
getValue() - Method in class org.glassfish.grizzly.http.Cookie
Returns the value of the cookie.
getValue() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
getValue(int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Returns the Nth header value, or null if there is no such header.
getValue(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Finds and returns a header field with the given name.
getValue(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Finds and returns a header field with the given name.
getValue() - Method in class org.glassfish.tyrus.core.TyrusExtension.TyrusParameter
 
getValueOfStringMethod(Class) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Get the static valueOf(String ) method.
getValues(K) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Return a non-null list of values for a given key.
getVariableSegmentIndices() - Method in class org.glassfish.tyrus.core.uri.Match
Get variable segment indices (indexes).
getVersion() - Method in class org.glassfish.grizzly.http.Cookie
Returns the version of the protocol this cookie complies with.
getWaitingConsumerCount() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
getWaitingConsumerCount() - Method in interface org.glassfish.grizzly.utils.TransferQueue
Returns an estimate of the number of consumers waiting to dequeue elements via take or poll.
getWebappResources() - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Gets the non-proxied resources of this AlternateDocBase.
getWebServerConfig() - Method in class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
Get the web server monitoring config.
getWebSocketContainer() - Static method in class javax.websocket.ContainerProvider
Obtain a new instance of a WebSocketContainer.
getWebSocketEngine() - Method in interface org.glassfish.tyrus.spi.ServerContainer
Returns WebSocketEngine to upgrade requests and setting up the connection
getWorkerThreadPool() - Method in class org.glassfish.grizzly.AbstractTransport
Get a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
getWorkerThreadPool() - Method in interface org.glassfish.grizzly.Transport
Get a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
getWorkerThreadPoolConfig() - Method in class org.glassfish.grizzly.AbstractTransport
getWorkerThreadPoolConfig() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getWorkerThreadPoolConfig() - Method in interface org.glassfish.grizzly.Transport
 
getWrapperNames(String, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
getWrappersString(String, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
getWritableMessage() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
getWriteBufferSize() - Method in class org.glassfish.grizzly.AbstractTransport
Get the default size of Buffers, which will be allocated for writing data to Transport's Connections.
getWriteBufferSize() - Method in interface org.glassfish.grizzly.Connection
Get the default size of Buffers, which will be allocated for writing data to Connection.
getWriteBufferSize() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Get the default size of Buffers, which will be allocated for writing data to Connection.
getWriteBufferSize() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
getWriteBufferSize() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Get the default size of Buffers, which will be allocated for writing data to Connection.
getWriteBufferSize() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getWriteBufferSize() - Method in interface org.glassfish.grizzly.Transport
Get the default size of Buffers, which will be allocated for writing data to Transport's Connections.
getWriter() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.ImmutableAsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
Get AsyncQueueWriter implementation.
getWriter() - Method in class org.glassfish.grizzly.http.server.Response
Return the NIOWriter associated with this Response.
getWriter() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
getWriter(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Get the Writer implementation, depending on the requested mode.
getWriter(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Get the Writer implementation, depending on the requested mode.
getWriter(Connection) - Method in interface org.glassfish.grizzly.Transport
Get the Writer to write data to the Connection.
getWriter(boolean) - Method in interface org.glassfish.grizzly.Transport
Get the Writer implementation, depending on the requested mode.
getWriter() - Method in interface org.glassfish.tyrus.spi.Connection
Returns the same writer that is passed for creating connection in WebSocketEngine.UpgradeInfo#createConnection(Writer, CloseListener) The transport writer that actually writes websocket data to underlying connection.
getWriteReentrant() - Static method in class org.glassfish.grizzly.Writer.Reentrant
Returns the current write reentrants counter.
getWriteTimeout(TimeUnit) - Method in class org.glassfish.grizzly.AbstractTransport
Returns the current value for the blocking write timeout converted to the provided TimeUnit specification.
getWriteTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Connection
Returns the current value for the blocking write timeout converted to the provided TimeUnit specification.
getWriteTimeout(TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
getWriteTimeout(TimeUnit) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
getWriteTimeout(TimeUnit) - Method in interface org.glassfish.grizzly.Transport
Returns the current value for the blocking write timeout converted to the provided TimeUnit specification.
getWrittenSize() - Method in class org.glassfish.grizzly.WriteResult
Get the number of bytes, which were written.
getX509Certificates(SSLSession) - Method in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
Globals - Class in org.glassfish.grizzly.http.server.util
Global constants that are applicable to multiple packages within Catalina.
Globals() - Constructor for class org.glassfish.grizzly.http.server.util.Globals
 
GONE_410 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
gracefullyCloseConnection(FilterChainContext) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
GracefulShutdownListener - Interface in org.glassfish.grizzly
Interface to notify interested parties that a Transport is being shutdown.
Grizzly - Class in org.glassfish.grizzly
Class contains information about Grizzly framework.
Grizzly() - Constructor for class org.glassfish.grizzly.Grizzly
 
GrizzlyClientContainer - Class in org.glassfish.tyrus.container.grizzly.client
 
GrizzlyClientContainer() - Constructor for class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientContainer
 
GrizzlyClientSocket - Class in org.glassfish.tyrus.container.grizzly.client
Implementation of the WebSocket interface.
GrizzlyContainerProvider - Class in org.glassfish.tyrus.container.grizzly.client
 
GrizzlyContainerProvider() - Constructor for class org.glassfish.tyrus.container.grizzly.client.GrizzlyContainerProvider
 
GrizzlyExecutorService - Class in org.glassfish.grizzly.threadpool
 
GrizzlyExecutorService(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
GrizzlyFuture<R> - Interface in org.glassfish.grizzly
Grizzly Future implementation.
GrizzlyJmxManager - Class in org.glassfish.grizzly.jmxbase
Grizzly JMX manager
GrizzlyJmxManager() - Constructor for class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
 
GrizzlyPrincipal - Class in org.glassfish.grizzly.http.server
Generic implementation of java.security.Principal that is used to represent principals authenticated at the protocol handler level.
GrizzlyPrincipal(String) - Constructor for class org.glassfish.grizzly.http.server.GrizzlyPrincipal
 
GrizzlyWriter - Class in org.glassfish.tyrus.container.grizzly.client
 
GrizzlyWriter(Connection) - Constructor for class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
GZIP_FILTER - Static variable in class org.glassfish.grizzly.http.server.Constants
GZIP filter (output).
GZipContentEncoding - Class in org.glassfish.grizzly.http
GZip ContentEncoding implementation, which compresses/decompresses HTTP content using gzip algorithm.
GZipContentEncoding() - Constructor for class org.glassfish.grizzly.http.GZipContentEncoding
Construct GZipContentEncoding using default buffer sizes.
GZipContentEncoding(int, int) - Constructor for class org.glassfish.grizzly.http.GZipContentEncoding
Construct GZipContentEncoding using specific buffer sizes.
GZipContentEncoding(int, int, EncodingFilter) - Constructor for class org.glassfish.grizzly.http.GZipContentEncoding
Construct GZipContentEncoding using specific buffer sizes.
GZipDecoder - Class in org.glassfish.grizzly.compression.zip
This class implements a Transformer which decodes data represented in the GZIP format.
GZipDecoder() - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder
 
GZipDecoder(int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder
 
GZipDecoder.DecodeStatus - Enum in org.glassfish.grizzly.compression.zip
 
GZipDecoder.GZipInputState - Class in org.glassfish.grizzly.compression.zip
 
GZipDecoder.GZipInputState() - Constructor for class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
GZipEncoder - Class in org.glassfish.grizzly.compression.zip
This class implements a Transformer which encodes plain data to the GZIP format.
GZipEncoder() - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder
 
GZipEncoder(int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder
 
GZipEncoder.GZipOutputState - Class in org.glassfish.grizzly.compression.zip
 
GZipEncoder.GZipOutputState() - Constructor for class org.glassfish.grizzly.compression.zip.GZipEncoder.GZipOutputState
 
GZipFilter - Class in org.glassfish.grizzly.compression.zip
This class implements a Filter which encodes/decodes data in the GZIP format.
GZipFilter() - Constructor for class org.glassfish.grizzly.compression.zip.GZipFilter
Construct GZipFilter using default buffer sizes.
GZipFilter(int, int) - Constructor for class org.glassfish.grizzly.compression.zip.GZipFilter
Construct GZipFilter using specific buffer sizes.

H

handle(String, Request, Response) - Method in class org.glassfish.grizzly.http.server.CLStaticHttpHandler
Lookup a resource based on the request URI, and send it using send file.
handle(String, Request, Response) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Lookup a resource based on the request URI, and send it using send file.
handle(String, Request, Response) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
Lookup a resource based on the request URI, and send it using send file.
handle(ByteBuffer) - Method in interface org.glassfish.tyrus.spi.ReadHandler
A transport reads websocket data and invokes this method to handover websocket data for a connection to tyrus runtime.
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when server channel has accepted the client connection.
handleAccept(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when server channel has accepted the client connection.
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates accept operation to Transport's specific transport filter.
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleAccept(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method perform the clean up of GZIP encoding/decoding state on a closed Connection.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when connection has been closed.
handleClose(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when connection has been closed.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates close operation to Transport's specific transport filter.
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleClose(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when channel gets connected.
handleConnect(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when channel gets connected.
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates connect operation to Transport's specific transport filter.
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleConnect(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Handle custom event associated with the Connection.
handleEvent(FilterChainContext, FilterChainEvent) - Method in interface org.glassfish.grizzly.filterchain.Filter
Handle custom event associated with the Connection.
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates event operation to Transport's specific transport filter.
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
handleGetSpecialHeader(String) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleGetSpecialHeader(Header) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleQueryParameters() - Method in class org.glassfish.grizzly.http.util.Parameters
Process the query string into parameters
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method decodes GZIP encoded data stored in FilterChainContext.getMessage() and, as the result, produces a Buffer with a plain data.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when channel will become available for reading.
handleRead(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when channel will become available for reading.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates reading operation to Transport's specific transport filter.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
The method is called, once we have received a Buffer, which has to be transformed into HTTP response packet part.
handleRead(FilterChainContext, HttpPacketParsing) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
The method is called by the specific HttpCodecFilter implementation, once we have received a Buffer, which has to be transformed into HTTP packet part.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
The method is called, once we have received a Buffer, which has to be transformed into HTTP request packet part.
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.http.server.FileCacheFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.DelayFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.EchoFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleRead(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handleSendFile(Request) - Static method in class org.glassfish.grizzly.http.server.util.RequestUtils
 
handleSetSpecialHeaders(String, String) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleSetSpecialHeaders(String, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleSetSpecialHeaders(Header, String) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleSetSpecialHeaders(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
 
handleTimeout() - Method in interface org.glassfish.tyrus.spi.ClientEngine.TimeoutHandler
Invoked when timeout is reached.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.compression.lzma.LZMAFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.compression.zip.GZipFilter
Method compresses plain data stored in FilterChainContext.getMessage() and, as the result, produces a Buffer with a GZIP compressed data.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.AbstractCodecFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
Execute a unit of processing work to be performed, when some data should be written on channel.
handleWrite(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.Filter
Execute a unit of processing work to be performed, when some data should be written on channel.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.TransportFilter
Delegates writing operation to Transport's specific transport filter.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
The method is called, once we need to serialize a HttpPacket, which may represent HTTP packet header, content or content chunk.
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.ActivityCheckFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.DelayFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.LogFilter
 
handleWrite(FilterChainContext) - Method in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
handshake(Connection) - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
handshake(Connection, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLCodec
 
handshake(Connection, CompletionHandler<SSLEngine>) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(Connection, CompletionHandler<SSLEngine>, Object) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(Connection, CompletionHandler<SSLEngine>, Object, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(Connection<?>, CompletionHandler<SSLEngine>, Object, SSLEngineConfigurator, FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
handshake(SSLStreamReader, SSLEngineConfigurator) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter
 
handshake(SSLStreamReader, SSLEngineConfigurator, CompletionHandler<SSLEngine>) - Method in class org.glassfish.grizzly.ssl.SSLStreamWriter
 
Handshake - Class in org.glassfish.tyrus.core
 
handshake(TyrusEndpointWrapper, UpgradeRequest, UpgradeResponse, ExtendedExtension.ExtensionContext) - Method in class org.glassfish.tyrus.core.ProtocolHandler
Server side.
HANDSHAKE_TIMEOUT - Static variable in class org.glassfish.tyrus.client.ClientManager
Property usable in ClientManager.getProperties().
HandshakeException - Exception in org.glassfish.tyrus.core
RuntimeException, which describes the error, occurred during the handshake phase.
HandshakeException(String) - Constructor for exception org.glassfish.tyrus.core.HandshakeException
Construct a HandshakeException.
HandshakeException(int, String) - Constructor for exception org.glassfish.tyrus.core.HandshakeException
Construct a HandshakeException.
handshakeListeners - Variable in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
HandshakeRequest - Interface in javax.websocket.server
The handshake request represents the web socket defined Http GET request for the opening handshake of a web socket session.
HandshakeResponse - Interface in javax.websocket
The handshake response represents the web socket-defined Http response that is the response to the opening handshake request.
handshakeUnwrap(SSLConnectionContext, Buffer, Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
handshakeWrap(Connection, SSLConnectionContext, Buffer) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
hasArray() - Method in interface org.glassfish.grizzly.Buffer
Tells whether or not this buffer is backed by an accessible byte array.
hasArray() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
hasArray() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
hasArray() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
hasAvailable() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Return true if StreamReader has available data, which could be read, or false otherwise.
hasAvailable() - Method in interface org.glassfish.grizzly.streams.StreamReader
Return true if StreamReader has available data, which could be read, or false otherwise.
hasExtensions() - Method in class org.glassfish.tyrus.core.ProtocolHandler
Returns true when current connection has some negotiated extension.
hash() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
hash() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
hash() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
hashCode() - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
hashCode() - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
hashCode() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
hashCode() - Method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
hashCode() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
hashCode() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
hashCode() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
hashCode() - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns DataChunk hash code.
hashCode() - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
hashCode() - Method in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
hashCode() - Method in class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
hashCode() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Returns the current hash code of this buffer.
hashCode() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
hashCode() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
hashCode() - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
hashCode() - Method in class org.glassfish.tyrus.core.TyrusExtension
 
hashCode() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap

This implementation delegates the method call to to the the underlying [key, multi-value] store.

hashCode() - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
 
hashCode() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Hashcode is calculated from String of the regular expression generated from the template.
hashIgnoreCase() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
hashIgnoreCase() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
hasInputRemaining(AttributeStorage, K) - Method in interface org.glassfish.grizzly.Transformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
hasInputRemaining(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
hasInputRemaining(AttributeStorage, String) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
hasLifeCycleListener(IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.Context
 
hasMoreElements() - Method in class org.glassfish.grizzly.http.server.util.Enumerator
Tests if this enumeration contains more elements.
hasNextFilter(FilterChainContext, int) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
hasPreviousFilter(FilterChainContext, int) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
hasProbes() - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
 
hasProbes() - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
 
hasRemaining() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Return true if this message has data remaining to be written.
hasRemaining() - Method in interface org.glassfish.grizzly.Buffer
Tells whether there are any elements between the current position and the limit.
hasRemaining() - Method in class org.glassfish.grizzly.FileTransfer
Return true if this message has data remaining to be written.
hasRemaining() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
hasRemaining() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
hasRemaining() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
hasRemaining() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
hasWaitingConsumer() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
hasWaitingConsumer() - Method in interface org.glassfish.grizzly.utils.TransferQueue
Returns true if there is at least one consumer waiting to dequeue an element via take or poll.
HEAD - Static variable in class org.glassfish.grizzly.http.Method
 
HEAD - Static variable in class org.glassfish.grizzly.http.server.Constants
HEAD.
header(String, String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Add the HTTP mime header.
header(Header, String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Add the HTTP mime header.
header(String, String) - Method in class org.glassfish.grizzly.http.HttpTrailer.Builder
Add the HTTP mime header.
Header - Enum in org.glassfish.grizzly.http.util
Enumeration of all headers as defined in RFC 2616.
headers - Variable in class org.glassfish.grizzly.http.HttpHeader
 
headers(MimeHeaders) - Method in class org.glassfish.grizzly.http.HttpTrailer.Builder
Set the mime headers.
HEADERS_MISSING() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Missing headers required for WebSocket negotiation.
HeaderValue - Class in org.glassfish.grizzly.http.util
This class serves as an HTTP header value holder, plus it implements useful utility methods to optimize headers serialization.
headerValueStorage - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
heap - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
HeapBuffer - Class in org.glassfish.grizzly.memory
Buffer implementation, which uses the ByteBuffer underneath.
HeapBuffer() - Constructor for class org.glassfish.grizzly.memory.HeapBuffer
 
HeapBuffer(byte[], int, int) - Constructor for class org.glassfish.grizzly.memory.HeapBuffer
 
HeapMemoryManager - Class in org.glassfish.grizzly.memory
A WrapperAware MemoryManager implementation for managing HeapBuffer instances.
HeapMemoryManager() - Constructor for class org.glassfish.grizzly.memory.HeapMemoryManager
 
HeapMemoryManager(int) - Constructor for class org.glassfish.grizzly.memory.HeapMemoryManager
 
hexDigit2Dec(byte) - Static method in class org.glassfish.grizzly.http.util.HexUtils
 
hexDigit2Dec(int) - Static method in class org.glassfish.grizzly.http.util.HexUtils
 
HexUtils - Class in org.glassfish.grizzly.http.util
Library of utility methods useful in dealing with converting byte arrays to and from strings of hexadecimal digits.
HexUtils() - Constructor for class org.glassfish.grizzly.http.util.HexUtils
 
Holder<E> - Class in org.glassfish.grizzly.utils
The object holder, which might be used for lazy object initialization.
Holder() - Constructor for class org.glassfish.grizzly.utils.Holder
 
Holder.IntHolder - Class in org.glassfish.grizzly.utils
 
Holder.IntHolder() - Constructor for class org.glassfish.grizzly.utils.Holder.IntHolder
 
Holder.LazyHolder<E> - Class in org.glassfish.grizzly.utils
 
Holder.LazyHolder() - Constructor for class org.glassfish.grizzly.utils.Holder.LazyHolder
 
Holder.LazyIntHolder - Class in org.glassfish.grizzly.utils
 
Holder.LazyIntHolder() - Constructor for class org.glassfish.grizzly.utils.Holder.LazyIntHolder
 
hookUp() - Method in class org.glassfish.tyrus.core.OsgiRegistry
Will hook up this instance with the OSGi runtime.
host - Variable in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
host(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Set the value for the Host header.
host - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
host - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
host - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
HOST - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
hosts - Variable in class org.glassfish.grizzly.http.server.util.Mapper
Array containing the virtual hosts definitions.
HT - Static variable in class org.glassfish.grizzly.http.server.Constants
HT.
HT - Static variable in class org.glassfish.grizzly.http.util.Constants
HT.
HtmlHelper - Class in org.glassfish.grizzly.http.server.util
Utility class used to generate HTML pages.
HtmlHelper() - Constructor for class org.glassfish.grizzly.http.server.util.HtmlHelper
 
HTTP_10 - Static variable in class org.glassfish.grizzly.http.server.Constants
HTTP/1.0.
HTTP_11 - Static variable in class org.glassfish.grizzly.http.server.Constants
HTTP/1.1.
HTTP_11_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
HTTP_SERVER_REQUEST_ATTR_NAME - Static variable in class org.glassfish.grizzly.http.HttpServerFilter
 
HTTP_VERSION_NOT_SUPPORTED_505 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
HttpBaseFilter - Class in org.glassfish.grizzly.http
Base HTTP Filter.
HttpBaseFilter() - Constructor for class org.glassfish.grizzly.http.HttpBaseFilter
 
HttpBrokenContent - Class in org.glassfish.grizzly.http
HttpContent message, which represents broken HTTP content.
HttpBrokenContent(HttpHeader) - Constructor for class org.glassfish.grizzly.http.HttpBrokenContent
 
HttpBrokenContent.Builder - Class in org.glassfish.grizzly.http
HttpTrailer message builder.
HttpBrokenContent.Builder() - Constructor for class org.glassfish.grizzly.http.HttpBrokenContent.Builder
 
HttpBrokenContentException - Exception in org.glassfish.grizzly.http
RuntimeException, means something wrong happened during HTTP message content parsing.
HttpBrokenContentException() - Constructor for exception org.glassfish.grizzly.http.HttpBrokenContentException
 
HttpBrokenContentException(String) - Constructor for exception org.glassfish.grizzly.http.HttpBrokenContentException
 
HttpBrokenContentException(Throwable) - Constructor for exception org.glassfish.grizzly.http.HttpBrokenContentException
 
HttpBrokenContentException(String, Throwable) - Constructor for exception org.glassfish.grizzly.http.HttpBrokenContentException
 
HttpClientFilter - Class in org.glassfish.grizzly.http
Client side HttpCodecFilter implementation, which is responsible for decoding HttpResponsePacket and encoding HttpRequestPacket messages.
HttpClientFilter() - Constructor for class org.glassfish.grizzly.http.HttpClientFilter
Constructor, which creates HttpClientFilter instance
HttpClientFilter(int) - Constructor for class org.glassfish.grizzly.http.HttpClientFilter
Constructor, which creates HttpClientFilter instance, with the specific secure and max header size parameter.
HttpCodecFilter - Class in org.glassfish.grizzly.http
The Filter, responsible for transforming Buffer into HttpPacket and vice versa in asynchronous mode.
HttpCodecFilter(boolean, int) - Constructor for class org.glassfish.grizzly.http.HttpCodecFilter
Constructor, which creates HttpCodecFilter instance, with the specific max header size parameter.
HttpCodecFilter.ContentParsingState - Class in org.glassfish.grizzly.http
 
HttpCodecFilter.ContentParsingState() - Constructor for class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
HttpCodecFilter.HeaderParsingState - Class in org.glassfish.grizzly.http
 
HttpCodecFilter.HeaderParsingState() - Constructor for class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
HttpCodecUtils - Class in org.glassfish.grizzly.http.util
General HttpCodec utility methods.
HttpCodecUtils() - Constructor for class org.glassfish.grizzly.http.util.HttpCodecUtils
 
HttpContent - Class in org.glassfish.grizzly.http
Object represents HTTP message content: complete or part.
HttpContent() - Constructor for class org.glassfish.grizzly.http.HttpContent
 
HttpContent(HttpHeader) - Constructor for class org.glassfish.grizzly.http.HttpContent
 
HttpContent(HttpHeader, boolean, Buffer) - Constructor for class org.glassfish.grizzly.http.HttpContent
 
HttpContent.Builder<T extends HttpContent.Builder> - Class in org.glassfish.grizzly.http
HttpContent message builder.
HttpContent.Builder() - Constructor for class org.glassfish.grizzly.http.HttpContent.Builder
 
httpContentBuilder() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the HTTP message content builder.
HttpContext - Class in org.glassfish.grizzly.http
Represents a single logical HTTP transaction.
HttpContext(AttributeStorage, OutputSink, Closeable) - Constructor for class org.glassfish.grizzly.http.HttpContext
 
httpContext - Variable in class org.glassfish.grizzly.http.server.Response
Grizzly HttpContext associated with the current Request/Response processing.
HttpHandler - Class in org.glassfish.grizzly.http.server
Base class to use when Request/Response/InputStream/OutputStream are needed to implement a customized HTTP container/extension to the HTTP module.
HttpHandler() - Constructor for class org.glassfish.grizzly.http.server.HttpHandler
Create HttpHandler.
HttpHandler(String) - Constructor for class org.glassfish.grizzly.http.server.HttpHandler
Create HttpHandler with the specific name.
HttpHandlerChain - Class in org.glassfish.grizzly.http.server
The HttpHandlerChain class allows the invocation of multiple HttpHandlers every time a new HTTP request is ready to be handled.
HttpHandlerChain(HttpServer) - Constructor for class org.glassfish.grizzly.http.server.HttpHandlerChain
 
httpHeader - Variable in class org.glassfish.grizzly.http.HttpContent.Builder
 
httpHeader(HttpHeader) - Method in class org.glassfish.grizzly.http.HttpContent.Builder
Set the HttpHeader associated with this content.
httpHeader - Variable in class org.glassfish.grizzly.http.HttpContent
 
HttpHeader - Class in org.glassfish.grizzly.http
HttpPacket, which represents HTTP message header.
HttpHeader() - Constructor for class org.glassfish.grizzly.http.HttpHeader
 
HttpHeader(MimeHeaders) - Constructor for class org.glassfish.grizzly.http.HttpHeader
 
HttpHeader.Builder<T extends HttpHeader.Builder> - Class in org.glassfish.grizzly.http
HttpHeader message builder.
HttpHeader.Builder() - Constructor for class org.glassfish.grizzly.http.HttpHeader.Builder
 
HttpPacket - Class in org.glassfish.grizzly.http
Abstraction, which represents any type of HTTP message: HttpRequestPacket, HttpResponsePacket, HttpContent.
HttpPacket() - Constructor for class org.glassfish.grizzly.http.HttpPacket
 
HttpPacketParsing - Interface in org.glassfish.grizzly.http
 
HttpPipelineOptAddOn - Class in org.glassfish.grizzly.http.server.util
The plugin, that optimizes processing of pipelined HTTP requests by buffering HTTP responses and then writing them as one operation.
HttpPipelineOptAddOn() - Constructor for class org.glassfish.grizzly.http.server.util.HttpPipelineOptAddOn
Constructs HttpPipelineOptAddOn.
HttpPipelineOptAddOn(int) - Constructor for class org.glassfish.grizzly.http.server.util.HttpPipelineOptAddOn
Constructs HttpPipelineOptAddOn.
HttpProbe - Interface in org.glassfish.grizzly.http
Monitoring probe providing callbacks that may be invoked by Grizzly Http filters.
HttpProbe.Adapter - Class in org.glassfish.grizzly.http
HttpProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
HttpProbe.Adapter() - Constructor for class org.glassfish.grizzly.http.HttpProbe.Adapter
 
HttpRequestPacket - Class in org.glassfish.grizzly.http
The HttpHeader object, which represents HTTP request message.
HttpRequestPacket() - Constructor for class org.glassfish.grizzly.http.HttpRequestPacket
 
HttpRequestPacket.Builder - Class in org.glassfish.grizzly.http
HttpRequestPacket message builder.
HttpRequestPacket.Builder() - Constructor for class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
HttpRequestURIDecoder - Class in org.glassfish.grizzly.http.util
Utility class that make sure an HTTP url defined inside a MessageBytes is normalized, converted and valid.
HttpRequestURIDecoder() - Constructor for class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
 
HttpResponsePacket - Class in org.glassfish.grizzly.http
The HttpHeader object, which represents HTTP response message.
HttpResponsePacket() - Constructor for class org.glassfish.grizzly.http.HttpResponsePacket
 
HttpResponsePacket.Builder - Class in org.glassfish.grizzly.http
HttpResponsePacket message builder.
HttpResponsePacket.Builder() - Constructor for class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
HttpServer - Class in org.glassfish.grizzly.http.server
 
HttpServer() - Constructor for class org.glassfish.grizzly.http.server.HttpServer
 
HttpServerFilter - Class in org.glassfish.grizzly.http
Server side HttpCodecFilter implementation, which is responsible for decoding HttpRequestPacket and encoding HttpResponsePacket messages.
HttpServerFilter() - Constructor for class org.glassfish.grizzly.http.HttpServerFilter
Deprecated.
Next major release will include builders for filters requiring configuration. Constructors will be hidden.
HttpServerFilter(boolean, int, KeepAlive, DelayedExecutor) - Constructor for class org.glassfish.grizzly.http.HttpServerFilter
Deprecated.
Next major release will include builders for filters requiring configuration. Constructors will be hidden.
HttpServerFilter(boolean, int, String, KeepAlive, DelayedExecutor) - Constructor for class org.glassfish.grizzly.http.HttpServerFilter
Deprecated.
Next major release will include builders for filters requiring configuration. Constructors will be hidden.
HttpServerFilter(boolean, int, String, KeepAlive, DelayedExecutor, int, int) - Constructor for class org.glassfish.grizzly.http.HttpServerFilter
Deprecated.
Next major release will include builders for filters requiring configuration. Constructors will be hidden.
HttpServerFilter - Class in org.glassfish.grizzly.http.server
Filter implementation to provide high-level HTTP request/response processing.
HttpServerFilter(ServerFilterConfiguration, DelayedExecutor) - Constructor for class org.glassfish.grizzly.http.server.HttpServerFilter
 
httpServerFilter - Variable in class org.glassfish.grizzly.http.server.Request
 
HttpServerMonitoringConfig - Class in org.glassfish.grizzly.http.server
Grizzly web server monitoring config.
HttpServerMonitoringConfig() - Constructor for class org.glassfish.grizzly.http.server.HttpServerMonitoringConfig
 
HttpServerProbe - Interface in org.glassfish.grizzly.http.server
Monitoring probe providing callbacks that may be invoked by Grizzly HttpServerFilter.
HttpServerProbe.Adapter - Class in org.glassfish.grizzly.http.server
HttpServerProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
HttpServerProbe.Adapter() - Constructor for class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
 
httpSession(Object) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set http session.
httpStatus - Variable in class org.glassfish.grizzly.http.HttpResponsePacket
Status code.
HttpStatus - Class in org.glassfish.grizzly.http.util
This enum encapsulates the HTTP response status and reason phrases as defined by RFC 2616.
HttpTrailer - Class in org.glassfish.grizzly.http
HttpContent message, which represents HTTP trailer message.
HttpTrailer(HttpHeader) - Constructor for class org.glassfish.grizzly.http.HttpTrailer
 
HttpTrailer.Builder - Class in org.glassfish.grizzly.http
HttpTrailer message builder.
HttpTrailer.Builder() - Constructor for class org.glassfish.grizzly.http.HttpTrailer.Builder
 
httpTrailerBuilder() - Method in class org.glassfish.grizzly.http.HttpHeader
Get the HTTP message trailer-chunk builder.
HttpUtils - Class in org.glassfish.grizzly.http.util
Utility class.
HttpUtils() - Constructor for class org.glassfish.grizzly.http.util.HttpUtils
 

I

ICloseType - Interface in org.glassfish.grizzly
Deprecated. 
IDENTITY - Static variable in class org.glassfish.grizzly.http.util.Constants
 
IDENTITY - Static variable in class org.glassfish.grizzly.http.util.HeaderValue
 
IDENTITY_FILTER - Static variable in class org.glassfish.grizzly.http.server.Constants
Identity filters (input and output).
IDLE_ATTRIBUTE_NAME - Static variable in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter - Class in org.glassfish.grizzly.utils
The Filter is responsible for tracking Connection activity and closing Connection ones it becomes idle for certain amount of time.
IdleTimeoutFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, IdleTimeoutFilter.TimeoutResolver) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, long, TimeUnit, IdleTimeoutFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, IdleTimeoutFilter.TimeoutResolver, IdleTimeoutFilter.TimeoutHandler) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter(DelayedExecutor, DelayedExecutor.Worker<Connection>, IdleTimeoutFilter.TimeoutResolver) - Constructor for class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
IdleTimeoutFilter.TimeoutHandler - Interface in org.glassfish.grizzly.utils
 
IdleTimeoutFilter.TimeoutResolver - Interface in org.glassfish.grizzly.utils
 
ILLEGAL_CONFIG_SYNTAX() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Illegal configuration-file syntax.
ILLEGAL_PROVIDER_CLASS_NAME(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Illegal provider-class name: {0}.
ILLEGAL_UTF_8_SEQUENCE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Illegal UTF-8 Sequence.
inc() - Method in class org.glassfish.grizzly.Writer.Reentrant
Increments the reentrants counter by one.
INCLUDE_CONTEXT_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the context path of the included servlet is stored on an included dispatcher request.
INCLUDE_PATH_INFO_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the path info of the included servlet is stored on an included dispatcher request.
INCLUDE_QUERY_STRING_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the query string of the included servlet is stored on an included dispatcher request.
INCLUDE_REQUEST_URI_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the request URI of the included servlet is stored on an included dispatcher request.
INCLUDE_SERVLET_PATH_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the servlet path of the included servlet is stored on an included dispatcher request.
INCOMING_BUFFER_SIZE - Static variable in class org.glassfish.tyrus.core.TyrusWebSocketEngine
 
INCOMING_BUFFER_SIZE - Static variable in interface org.glassfish.tyrus.spi.ClientContainer
Property name for maximal incoming buffer size.
INCOMPLETE_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
INCOMPLETED - Static variable in interface org.glassfish.grizzly.Interceptor
 
incrementDispatchDepth() - Method in class org.glassfish.grizzly.http.server.Request
Increment the depth of application dispatch
index() - Method in class org.glassfish.grizzly.attributes.Attribute
Return attribute name, which is used as attribute key on indexed AttributeHolders.
IndexedAttributeAccessor - Interface in org.glassfish.grizzly.attributes
The interface declares, that AttributeHolder supports indexed Attribute access.
indexedAttributeAccessor - Variable in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
 
IndexedAttributeHolder - Class in org.glassfish.grizzly.attributes
AttributeHolder, which supports indexed access to stored Attributes.
IndexedAttributeHolder(AttributeBuilder) - Constructor for class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Deprecated.
use AttributeBuilder#createAttributeHolder()
IndexedAttributeHolder.IndexedAttributeAccessorImpl - Class in org.glassfish.grizzly.attributes
IndexedAttributeAccessor implementation.
IndexedAttributeHolder.IndexedAttributeAccessorImpl() - Constructor for class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
 
indexOf(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
indexOf(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
indexOf(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
indexOf(char, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
indexOf(Buffer, int, int, char) - Static method in class org.glassfish.grizzly.http.util.BufferChunk
 
indexOf(Buffer, int, int, CharSequence) - Static method in class org.glassfish.grizzly.http.util.BufferChunk
 
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
indexOf(String, int, int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
indexOf(char, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns true if the message bytes starts with the specified string.
indexOf(byte[], int, int, char) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
 
indexOf(char) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
indexOf(char, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns true if the message bytes starts with the specified string.
indexOf(char[], int, int, char) - Static method in class org.glassfish.grizzly.http.util.CharChunk
 
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
indexOf(String, int, int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
indexOf(char, int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
indexOf(String, int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
indexOf(char, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns true if the message bytes starts with the specified string.
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns true if the message bytes starts with the specified string.
indexOf(Buffer, int, byte, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
indexOf(char) - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
indexOf(String) - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
indexOf(char, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns true if the message bytes starts with the specified string.
indexOf(String, int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Find the index of a header with the given name.
indexOf(Header, int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Find the index of a header with the given name.
indexOf(T[], Object) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Return the element index in the array.
indexOfIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
indexOfRemainder(DefaultFilterChain.FiltersState, FilterChainContext.Operation, int, int) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Locates a message remainder in the FilterChain, associated with the Connection.
indexOfType(Class<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Get the index of Filter in chain, which type is filterType, or -1 if the Filter of required type was not found.
indexOfType(Class<? extends Filter>) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
Get the index of Filter in chain, which type is filterType, or -1 if the Filter of required type was not found.
indexOfType(Class<? extends Filter>) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
info - Static variable in class org.glassfish.grizzly.http.server.Response
Descriptive information about this Response implementation.
INFO_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_INFO(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0156: Character decoding failed.
INFO_GRIZZLY_HTTP_PARAMETERS_INVALID_CHUNK(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0155: Invalid chunk starting at byte [{0}] and ending at byte [{1}] with a value of [{2}] ignored
INFO_GRIZZLY_HTTP_PARAMETERS_MULTIPLE_DECODING_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0157: Character decoding failed.
init(EndpointConfig) - Method in interface javax.websocket.Decoder
This method is called with the endpoint configuration object of the endpoint this decoder is intended for when it is about to be brought into service.
init(EndpointConfig) - Method in interface javax.websocket.Encoder
This method is called with the endpoint configuration object of the endpoint this encoder is intended for when it is about to be brought into service.
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder.Decoder2
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder.LiteralDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
init(boolean) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
init() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
init(String) - Method in class org.glassfish.grizzly.http.util.B2CConverter
 
init(Buffer, int, int) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
init(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
init(EndpointConfig) - Method in class org.glassfish.tyrus.core.coder.CoderAdapter
This method does nothing.
initBitModels(short[]) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
initBitModels(short[]) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
initClusteredSession(String, String, SessionEventListener) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Initializes cluster session.
initFromState(LZMADecoder.LZMAInputState) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
initFromState(LZMADecoder.LZMAInputState) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
INITIAL_SIZE - Static variable in class org.glassfish.grizzly.http.util.Parameters
 
initialClassLoader - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
initialize(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
initialize(HttpCodecFilter, int, int) - Method in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
initialize(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Per-request initialization required for the InputBuffer to function properly.
initialize(HttpHeader, boolean, FilterChainContext) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
initialize(DelayedExecutor) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
initialize(Request, FilterChainContext) - Method in class org.glassfish.grizzly.http.server.io.ServerInputBuffer
 
initialize(Response, FilterChainContext) - Method in class org.glassfish.grizzly.http.server.io.ServerOutputBuffer
 
initialize(HttpRequestPacket, FilterChainContext, HttpServerFilter) - Method in class org.glassfish.grizzly.http.server.Request
 
initialize(Request, HttpResponsePacket, FilterChainContext, DelayedExecutor.DelayQueue<Response.SuspendTimeout>, HttpServerFilter) - Method in class org.glassfish.grizzly.http.server.Response
 
initialized() - Method in class org.glassfish.grizzly.http.Cookies
 
initiateAsyncronousDataReceiving() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Initiates asynchronous data receiving.
initIndexes(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
inner1State - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
inner2State - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
input - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
Input - Interface in org.glassfish.grizzly.streams
 
InputBuffer - Class in org.glassfish.grizzly.http.io
Abstraction exposing both byte and character methods to read content from the HTTP messaging system in Grizzly.
InputBuffer() - Constructor for class org.glassfish.grizzly.http.io.InputBuffer
 
inputBuffer - Variable in class org.glassfish.grizzly.http.server.Request
The associated input buffer.
InputSource - Interface in org.glassfish.grizzly
This interface defines methods to allow an InputStream or Reader to notify the developer when and how much data is ready to be read without blocking.
InputStreamDecoder - Class in org.glassfish.tyrus.core.coder
Built in Decoder for InputStream.
InputStreamDecoder() - Constructor for class org.glassfish.tyrus.core.coder.InputStreamDecoder
 
instance() - Static method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Return the GrizzlyJmxManager instance.
INSTANCE - Static variable in class org.glassfish.grizzly.StandaloneProcessor
 
INSTANCE - Static variable in class org.glassfish.grizzly.StandaloneProcessorSelector
 
intercept(int, Object, R) - Method in interface org.glassfish.grizzly.Interceptor
Callback method is called by Readable, so it is possible to customize reading process.
interceptor - Variable in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
Interceptor<R> - Interface in org.glassfish.grizzly
Handler, which is used to finer control Readable.
interestedIoEventsMask - Variable in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
INTERNAL_SERVER_ERROR_500 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
intToHexString(Buffer, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
intToUnsignedString(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Convert the integer to an unsigned number.
INVALID_HEADER(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Invalid {0} header value: "{1}".
INVALID_RESPONSE_CODE(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Response code was not {0}: {1}.
INVOKED_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which the Invoker servlet will store the invoking servlet path, if it was used to execute a servlet indirectly instead of through a servlet mapping.
InWindow - Class in org.glassfish.grizzly.compression.lzma.impl.lz
InWindow
InWindow() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
ioEvent - Variable in class org.glassfish.grizzly.Context
Processing IOEvent
IOEvent - Enum in org.glassfish.grizzly
Enumeration represents the I/O events, occurred on a Connection.
ioEvent2SelectionKeyInterest(IOEvent) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
ioEvent2SelectionKeyInterest(IOEvent) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
IOEventLifeCycleListener - Interface in org.glassfish.grizzly
The IOEvent life-cycle listener, which will be notified about changes in IOEvent processing statuses.
IOEventLifeCycleListener.Adapter - Class in org.glassfish.grizzly
Empty IOEventLifeCycleListener implementation.
IOEventLifeCycleListener.Adapter() - Constructor for class org.glassfish.grizzly.IOEventLifeCycleListener.Adapter
 
IOEXCEPTION_CLOSE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
IOException thrown when closing connection.
IOStrategy - Interface in org.glassfish.grizzly
strategy is responsible for making decision how Runnable task will be run: in current thread, worker thread.
ioStrategy - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
IS_WORKAROUND_SELECTOR_SPIN - Static variable in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
isAcknowledgement() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
isAllowCustomReasonPhrase() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Returns true if custom status reason phrases are allowed for this response, or false otherwise.
isAllowCustomStatusMessage() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Returns true if custom status messages (reason phrases) are allowed for this response, or false otherwise.
isAllowDirectWrite() - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Returns true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
isAllowDirectWrite() - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Returns true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
isAllowEncodedSlash() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Is HTTP URL request allowed to contains encoded slash.
isAllowEncodedSlash() - Method in class org.glassfish.grizzly.http.util.UDecoder
 
isAlpha(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns true if the specified ASCII character is upper or lower case.
isApplicable(Class<?>) - Method in class org.glassfish.tyrus.core.ComponentProvider
Checks whether this component provider is able to provide an instance of given Class.
isApplicable(Class<?>) - Method in class org.glassfish.tyrus.core.DefaultComponentProvider
 
isAsyncEnabled() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Deprecated.
will always return true
isAsyncEnabled() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Deprecated.
will always return true
isAuthPassThroughEnabled() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isBlocking - Variable in class org.glassfish.grizzly.AbstractTransport
Transport mode
isBlocking() - Method in class org.glassfish.grizzly.AbstractTransport
Returns the Transport mode.
isBlocking() - Method in interface org.glassfish.grizzly.Connection
 
isBlocking() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
isBlocking - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
isBlocking() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isBlocking() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
isBlocking() - Method in interface org.glassfish.grizzly.Transport
Returns the Transport mode.
isBroken(HttpContent) - Static method in class org.glassfish.grizzly.http.HttpContent
Returns true if passed HttpContent is a BrokenHttpContent.
isBuffered() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
isBuffered() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
isBuffered() - Method in interface org.glassfish.grizzly.streams.Input
 
isBuffered() - Method in interface org.glassfish.grizzly.streams.Output
 
isBuffered() - Method in class org.glassfish.grizzly.streams.StreamInput
 
isBuffered() - Method in class org.glassfish.grizzly.streams.StreamOutput
 
isCacheEnabled() - Method in class org.glassfish.grizzly.http.server.Response
Is the file cache enabled?
isCancelled() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
isCancelled() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
isCancelled - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
isCancelled() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
isCancelled() - Method in class org.glassfish.tyrus.core.TyrusFuture
 
isChunked - Variable in class org.glassfish.grizzly.http.HttpHeader
 
isChunked() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if this HttpPacket content will be transferred in chunking mode, or false if case of fixed-length message.
isChunkingAllowed() - Method in class org.glassfish.grizzly.http.HttpHeader
Return true if chunking is allowed for this header.
isChunkingEnabled() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Return true if chunked transfer-encoding may be used.
isChunkingEnabled() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isCipherConfigured() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isClientMode() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Will SSLEngine be configured to work in client mode.
isClientSupportCompression(CompressionConfig, HttpRequestPacket, String[]) - Static method in class org.glassfish.grizzly.http.CompressionConfig
Returns true if a client, based on its HttpRequestPacket, could be responded with compressed data, or false otherwise.
isClosed() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
isClosed() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
isClosed() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isClosed - Variable in class org.glassfish.grizzly.streams.AbstractStreamReader
 
isClosed() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Returns true, if StreamReader has been closed, or false otherwise.
isClosed() - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Returns true, if StreamReader has been closed, or false otherwise.
isClosed - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 
isClosed() - Method in interface org.glassfish.grizzly.streams.StreamReader
Returns true, if StreamReader has been closed, or false otherwise.
isClosed() - Method in interface org.glassfish.grizzly.streams.StreamWriter
Returns true, if StreamReader has been closed, or false otherwise.
isCommitted - Variable in class org.glassfish.grizzly.http.HttpHeader
 
isCommitted() - Method in class org.glassfish.grizzly.http.HttpHeader
Is this HttpHeader written? true, if this HttpHeader has been already serialized, and only HttpContent messages might be serialized for this HttpPacket.
isCommitted() - Method in class org.glassfish.grizzly.http.server.Response
Has the output of this response already been committed?
isCompletionHandlerRegistered - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
isComposite() - Method in interface org.glassfish.grizzly.Buffer
 
isComposite() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isComposite() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isComposite() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isConnected() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
isConnected() - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Convenience method to determine if this TyrusWebSocket instance is connected.
isContent(HttpPacket) - Static method in class org.glassfish.grizzly.http.HttpContent
Returns true if passed HttpPacket is a HttpContent.
isContentBroken - Variable in class org.glassfish.grizzly.http.HttpHeader
true if HTTP message payload is broken due to inappropriate Transfer-Encoding or Content-Encoding settings.
isContentBroken() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if HTTP packet payload was detected as broken due to unexpected error occurred during Transfer-Encoding or Content-Encoding processing.
isContentEncodingsSelected() - Method in class org.glassfish.grizzly.http.HttpHeader
 
isContentLengthHeader - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
isContentTypeSet() - Method in class org.glassfish.grizzly.http.HttpHeader
 
isControlFrame() - Method in class org.glassfish.tyrus.core.frame.Frame
Get information about frame type.
isCustomReasonPhraseSet() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
isDaemon - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
isDaemon() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
isDecoded() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
isDefaultContext - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
isDigit(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns true if the specified ASCII character is a digit.
isDirect() - Method in interface org.glassfish.grizzly.Buffer
Tells whether or not this buffer is direct.
isDirect() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isDirect - Variable in class org.glassfish.grizzly.memory.ByteBufferManager
Is direct ByteBuffer should be used?
isDirect() - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns true, if ByteBufferManager works with direct ByteBuffers, or false otherwise.
isDirect() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isDirect() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isDisableUploadTimeout() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isDone() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
isDone() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
isDone - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
isDone() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
isDone() - Method in class org.glassfish.tyrus.core.TyrusFuture
 
isDownstream() - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
isEmpty() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
isEmpty() - Method in class org.glassfish.grizzly.ChainProcessorSelector
isEmpty() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
isEmpty() - Method in class org.glassfish.grizzly.utils.ArraySet
isEmpty() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Returns true if this queue contains no elements.
isEmpty() - Method in class org.glassfish.tyrus.core.ErrorCollector
Checks whether any exception has been logged.
isEmpty() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
isEmptyRecord() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
isEnabled() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
isEncodeable(String) - Method in class org.glassfish.grizzly.http.server.Response
Return true if the specified URL should be encoded with a session identifier.
isEquivalent(String, String) - Static method in class org.glassfish.tyrus.core.uri.Match
Check for equivalent paths.
isError() - Method in class org.glassfish.grizzly.http.ProcessingState
This flag indicates whether error occurred during the HTTP processing.
isError() - Method in class org.glassfish.grizzly.http.server.Response
Error flag accessor.
isExact() - Method in class org.glassfish.tyrus.core.uri.Match
TODO.
isExpectContent - Variable in class org.glassfish.grizzly.http.HttpHeader
 
isExpectContent() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if HTTP message, represented by this header still expects additional content basing either on content-length or chunking information.
isExternal() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.FileTransfer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isExternal() - Method in class org.glassfish.grizzly.memory.HeapBuffer
Returns true if the message represents an external resource (for example FileTransfer), which is not loaded in memory.
isFileCacheEnabled() - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
Returns true if this StaticHttpHandler has been configured to use file cache to serve static resources, or false otherwise.
isFileSendEnabled() - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Returns true if File resources may be be sent using FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel).
isFin() - Method in class org.glassfish.tyrus.core.frame.Frame
Get FIN value.
isFinished() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
isFinished() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
isFinished() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
isFinished() - Method in interface org.glassfish.grizzly.InputSource
 
isHandshaking(SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
isHeader() - Method in class org.glassfish.grizzly.http.HttpContent
Returns true, if this HTTP message represents HTTP message header, or false otherwise.
isHeader() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true.
isHeader() - Method in class org.glassfish.grizzly.http.HttpPacket
Returns true, if this HTTP message represents HTTP message header, or false otherwise.
isHeaderParsed() - Method in interface org.glassfish.grizzly.http.HttpPacketParsing
 
isHeaderWritten() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
isHeadRequest() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns true if this request is a HEAD request, otherwise returns false.
isHexCharacter(char) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Checks whether the character c is hexadecimal character.
isHexDigit(byte) - Static method in class org.glassfish.grizzly.http.util.HexUtils
 
isHexDigit(int) - Static method in class org.glassfish.grizzly.http.util.HexUtils
 
isHtmlEncodingCustomReasonPhrase() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Returns if we need to encode HTML sensitive characters in custom reason phrase.
isHttp(Object) - Static method in class org.glassfish.grizzly.http.HttpPacket
Returns true if passed Object is a HttpPacket.
isHttpOnly - Variable in class org.glassfish.grizzly.http.Cookie
 
isHttpOnly() - Method in class org.glassfish.grizzly.http.Cookie
HttpOnly feature is used in server->client communication only to let client know, that the cookie can not be accessed on the client-side (script etc).
isInitialized() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
isInitialized() - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
isInterested(IOEvent) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Is this Processor interested in processing the i/o event
isInterested(IOEvent) - Method in interface org.glassfish.grizzly.Processor
Is this Processor interested in processing the i/o event
isInterested(IOEvent) - Method in class org.glassfish.grizzly.StandaloneProcessor
StandaloneProcessor is not interested in any IOEvent.
isJmxEnabled() - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
 
isKeepAlive() - Method in class org.glassfish.grizzly.http.ProcessingState
This flag controls the connection keep-alive feature.
isKeepAlive() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
isKeepAlive() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isLast() - Method in class org.glassfish.grizzly.http.HttpBrokenContent
Always true true for the trailer message.
isLast - Variable in class org.glassfish.grizzly.http.HttpContent
 
isLast() - Method in class org.glassfish.grizzly.http.HttpContent
Return true, if the current content chunk is last, or false, if there are content chunks to follow.
isLast() - Method in class org.glassfish.grizzly.http.HttpTrailer
Always true true for the trailer message.
isLastAllocated(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
isLastChunk - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
isLocked() - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Return the locked state of this parameter map.
isLower(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns true if the specified ASCII character is lower case.
isManualIOEventControl - Variable in class org.glassfish.grizzly.Context
 
isManualIOEventControl() - Method in class org.glassfish.grizzly.Context
 
isMask() - Method in class org.glassfish.tyrus.core.frame.Frame
Currently not used.
isMaxDispatchDepthReached() - Method in class org.glassfish.grizzly.http.server.Request
Check if the application dispatching has reached the maximum
isMaxReentrantsReached() - Method in class org.glassfish.grizzly.Writer.Reentrant
Returns true, if max number of write->completion-handler reentrants has been reached for the passed Writer.Reentrant object, and next write will happen in the separate thread.
isMimeTypeSet() - Method in class org.glassfish.grizzly.http.util.ContentType
 
isNeedClientAuth() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isNew() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
isNonPrintableUsAscii(int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
Returns true if the passed symbol code represents a non-printable US-ASCII symbol in range [Integer.MIN_VALUE; 9) U (9; 31] U [127; Integer.MAX_VALUE].
isNotSpaceAndTab(byte) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
isNull() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
isNull() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
isNull() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
isNull() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
isNull() - Method in class org.glassfish.grizzly.http.util.MessageBytes
 
isOK() - Method in class javax.websocket.SendResult
Determines if this result is ok or not.
isOpen() - Method in interface javax.websocket.Session
Return true if and only if the underlying socket is open.
isOpen() - Method in interface org.glassfish.grizzly.Connection
Is Connection open and ready.
isOpen() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isOpen() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
isOpen() - Method in class org.glassfish.tyrus.core.TyrusSession
 
isOptimizedForMultiplexing() - Method in class org.glassfish.grizzly.nio.NIOTransport
Returns true, if NIOTransport is configured to use AsyncQueueWriter, optimized to be used in connection multiplexing mode, or false otherwise.
isOptimizedForMultiplexing() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
isOutputBuffered - Variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
isPassTraceRequest() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
isPaused() - Method in class org.glassfish.grizzly.AbstractTransport
isPaused() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isPaused() - Method in interface org.glassfish.grizzly.Transport
 
isProtocolConfigured() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isReadOnly() - Method in interface org.glassfish.grizzly.Buffer
Tells whether or not this buffer is read-only.
isReadOnly() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
isReadOnly() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
isReadOnly() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
isReadWrite(IOEvent) - Static method in class org.glassfish.grizzly.strategies.AbstractIOStrategy
 
isReady(Connection) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReady() - Method in interface org.glassfish.grizzly.InputSource
 
isReady(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReady(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Checks whether there is ready data in AsyncQueue, associated with the Connection.
isReallocate() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
Returns true if "reallocate" strategy is used or false otherwise.
isRecycled - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
isRequest() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if the current HttpHeader represent HTTP request message, or false otherwise.
isRequest() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Returns true, if the current HttpHeader represent HTTP request message, or false otherwise.
isRequest() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Returns true, if the current HttpHeader represent HTTP request message, or false otherwise.
isRequestedSessionIdFromCookie() - Method in class org.glassfish.grizzly.http.server.Request
Return true if the session identifier included in this request came from a cookie.
isRequestedSessionIdFromURL() - Method in class org.glassfish.grizzly.http.server.Request
Return true if the session identifier included in this request came from the request URI.
isRequestedSessionIdValid() - Method in class org.glassfish.grizzly.http.server.Request
Return true if the session identifier included in this request identifies a valid session.
isReuseAddress() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
isReuseAddress - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
isReuseAddress - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
isReuseAddress() - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
isReuseSessionID() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Returns the "reuse session IDs when creating sessions"
isRsv1() - Method in class org.glassfish.tyrus.core.frame.Frame
GET RSV1 value.
isRsv2() - Method in class org.glassfish.tyrus.core.frame.Frame
GET RSV2 value.
isRsv3() - Method in class org.glassfish.tyrus.core.frame.Frame
GET RSV3 value.
isSecure() - Method in interface javax.websocket.Session
Return true if and only if the underlying socket is using a secure transport.
isSecure() - Method in class org.glassfish.grizzly.http.Cookie
Returns true if the browser is sending cookies only over a secure protocol, or false if the browser can send cookies using any protocol.
isSecure(Connection) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
flag, which indicates whether this HttpCodecFilter is dealing with the secured HTTP packets.
isSecure() - Method in class org.glassfish.grizzly.http.HttpHeader
 
isSecure() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isSecure() - Method in class org.glassfish.grizzly.http.server.Request
Was this request received on a secure connection?
isSecure() - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
 
isSecure() - Method in class org.glassfish.tyrus.core.RequestContext
 
isSecure() - Method in class org.glassfish.tyrus.core.TyrusSession
 
isSecure() - Method in class org.glassfish.tyrus.spi.UpgradeRequest
Indicates whether this request was made using a secure channel (such as HTTPS).
isSendFileEnabled() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isSendFileEnabled() - Method in class org.glassfish.grizzly.http.server.Response
 
isSendFileEnabled() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Returns true if File resources may be be sent using FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel).
isSeparator(int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Returns true if the byte is a separator character as defined in RFC2619.
isSeparator(int, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
isSerialized(int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Get the header's "serialized" flag.
isServerMode() - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
isService() - Static method in class org.glassfish.grizzly.threadpool.Threads
 
isSet(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Checks if this attribute is set on the AttributeHolder.
isSet(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Checks if this attribute is set on the AttributeStorage.
isSet() - Method in class org.glassfish.grizzly.http.util.ContentType
 
isSet() - Method in class org.glassfish.grizzly.http.util.HeaderValue
 
isShutdown() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
isShutdown() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
isSkipRemainder - Variable in class org.glassfish.grizzly.http.HttpHeader
 
isSkipRemainder() - Method in class org.glassfish.grizzly.http.HttpHeader
Returns true, if either application or HTTP core part is not interested in parsing the rest of this HTTP message content and waits for the next HTTP message to come on this Connection.
isSpaceOrTab(byte) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
isSpecialHeader(String) - Static method in class org.glassfish.grizzly.http.HttpHeader
 
isStandalone - Variable in class org.glassfish.grizzly.AbstractTransport
 
isStandalone() - Method in class org.glassfish.grizzly.AbstractTransport
 
isStandalone() - Method in interface org.glassfish.grizzly.Connection
Deprecated.
isStandalone - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
isStandalone() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
isStandalone() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
isStandalone() - Method in interface org.glassfish.grizzly.Transport
 
isStarted() - Method in class org.glassfish.grizzly.http.server.HttpServer
 
isStarted() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isStayAlive() - Method in class org.glassfish.grizzly.http.ProcessingState
Method returns true only if the connection is in keep-alive mode and there was no error occurred during the packet processing.
isStopped() - Method in class org.glassfish.grizzly.AbstractTransport
Returns true, if this Transport is in stopped state, false otherwise.
isStopped() - Method in interface org.glassfish.grizzly.Transport
Returns true, if this Transport is in stopped state, false otherwise.
isSupportBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
isSupportBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
isSuspended() - Method in class org.glassfish.grizzly.http.server.Response
Return true if that Response.suspend() has been invoked and set to true
isSuspended() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
isSuspended() - Method in interface org.glassfish.grizzly.http.server.SuspendContext
Returns true, if the Response is suspended, or false otherwise.
isTcpNoDelay() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
isTcpNoDelay() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
isTemplateVariablePresent(String) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Ascertain if a template variable is a member of this template.
isTerminated() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
isTerminated() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
isToken(String) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
isToken(String, String) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
isToken2(String) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
isToken2(String, String) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
 
isTraceEnabled() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
isTraceEnabled() - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
isTrackingThreadCache() - Static method in class org.glassfish.grizzly.Grizzly
 
isTrailer(HttpContent) - Static method in class org.glassfish.grizzly.http.HttpTrailer
Returns true if passed HttpContent is a HttpTrailder.
isTransferEncodingHeader - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
isUnsafeSupported() - Method in class org.glassfish.grizzly.utils.JdkVersion
Returns true if sun.misc.Unsafe is present in the current JDK version, or false otherwise.
isUpgradeHeader - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
isUpper(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns true if the specified ASCII character is upper case.
isUpstream() - Method in interface org.glassfish.grizzly.filterchain.FilterExecutor
 
isUserInRole(String) - Method in interface javax.websocket.server.HandshakeRequest
Checks whether the current user is in the given role.
isUserInRole(String) - Method in interface org.glassfish.tyrus.core.RequestContext.Builder.IsUserInRoleDelegate
Returns a boolean indicating whether the authenticated user is included in the specified logical "role".
isUserInRole(String) - Method in class org.glassfish.tyrus.core.RequestContext
 
isUserInRoleDelegate(RequestContext.Builder.IsUserInRoleDelegate) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set delegate for RequestContext.isUserInRole(String) method.
isValid() - Method in class org.glassfish.grizzly.http.server.Session
Is the current Session valid?
isValid() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
isValid() - Method in interface org.glassfish.tyrus.container.grizzly.client.TaskProcessor.Condition
Check the condition.
isVersionSet() - Method in class org.glassfish.grizzly.http.Cookie
 
isWantClientAuth() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
isWhite(char) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Is the specified character considered to be whitespace?
isWhite(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns true if the specified ASCII character is white space.
isWhiteSpace(int) - Static method in class org.glassfish.grizzly.http.util.CookieUtils
Returns true if the byte is a whitespace character as defined in RFC2619.
iterator() - Method in class org.glassfish.grizzly.ChainProcessorSelector
iterator() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
iterator() - Method in class org.glassfish.grizzly.utils.ArraySet
iterator() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Returns an iterator over the elements in this queue in proper sequence.
iterator() - Method in class org.glassfish.grizzly.utils.ServiceFinder
Returns discovered objects incrementally.
iterator() - Method in class org.glassfish.tyrus.core.ServiceFinder
Returns discovered objects incrementally.

J

javax.websocket - package javax.websocket
This package contains all the WebSocket APIs common to both the client and server side.
javax.websocket.server - package javax.websocket.server
This package contains all the WebSocket APIs used only by server side applications.
JdkVersion - Class in org.glassfish.grizzly.utils
 
jmxDisabled() - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
 
jmxDisabled() - Method in interface org.glassfish.grizzly.http.server.jmxbase.JmxEventListener
Invoked when JMX has been disabled.
jmxEnabled() - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
 
jmxEnabled() - Method in interface org.glassfish.grizzly.http.server.jmxbase.JmxEventListener
Invoked when JMX has been enabled.
JmxEventListener - Interface in org.glassfish.grizzly.http.server.jmxbase
Notify implementations when JMX is enabled on a HttpServer instance.
jmxManager - Variable in class org.glassfish.grizzly.http.server.HttpServer
 
join(InetAddress, NetworkInterface) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Joins a multicast group to begin receiving all datagrams sent to the group.
join(InetAddress, NetworkInterface, InetAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Joins a multicast group to begin receiving datagrams sent to the group from a given source address.
JROUTE_COOKIE - Static variable in class org.glassfish.grizzly.http.server.Constants
 
JSP_FILE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we expose the value of the <jsp-file> value associated with this servlet, if any.
jspWildCard - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Wrapper
 
jspWildCard - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 

K

kAlignMask - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kAlignTableSize - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kDicLogSizeMin - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
KEEP_ALIVE_TIMEOUT_IN_SECONDS - Static variable in class org.glassfish.grizzly.http.util.Constants
 
KeepAlive - Class in org.glassfish.grizzly.http
Web container configuration for keep-alive HTTP connections.
KeepAlive() - Constructor for class org.glassfish.grizzly.http.KeepAlive
 
KEEPALIVE - Static variable in class org.glassfish.grizzly.http.server.Constants
 
keepAlive - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
KEEPALIVE_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
KeepAliveProbe - Interface in org.glassfish.grizzly.http
Monitoring probe providing callbacks that may be invoked by Grizzly KeepAlive.
KeepAliveProbe.Adapter - Class in org.glassfish.grizzly.http
KeepAliveProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
KeepAliveProbe.Adapter() - Constructor for class org.glassfish.grizzly.http.KeepAliveProbe.Adapter
 
keepAliveTimeMillis - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
kEndPosModelIndex - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kernelConfig - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
kernelPool - Variable in class org.glassfish.grizzly.AbstractTransport
Kernel thread pool.
kernelPoolConfig - Variable in class org.glassfish.grizzly.AbstractTransport
 
key - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
KEY_FACTORY_MANAGER_ALGORITHM - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_SIZE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we store the key size being used for this SSL connection (as an object of type java.lang.Integer).
KEY_SIZE_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the key size.
KEY_SIZE_KEY - Static variable in class org.glassfish.grizzly.ssl.SSLSupportImpl
 
KEY_STORE_FILE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_PASSWORD - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_PROVIDER - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
KEY_STORE_TYPE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
keySet() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
keySize - Variable in class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
kMatchMaxLen - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kMatchMinLen - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumAlignBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumBitPriceShiftBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
kNumFullDistances - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumHighLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenSpecSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
kNumLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenToPosStates - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLenToPosStatesBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLitContextBitsMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLitPosStatesBitsEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLowLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumLowLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumMidLenBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumMidLenSymbols - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosModels - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosSlotBits - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesBitsEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesBitsMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesEncodingMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumPosStatesMax - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumRepDistances - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kNumStates - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 
kStartPosModelIndex - Static variable in class org.glassfish.grizzly.compression.lzma.impl.Base
 

L

last - Variable in class org.glassfish.grizzly.http.HttpContent.Builder
 
last(boolean) - Method in class org.glassfish.grizzly.http.HttpContent.Builder
Set whether this HttpContent chunk is the last.
lastIndexOf(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
lastIndexOf(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
lastMethodResult - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
lastModified - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
lastModifiedHeader - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
lastResult - Variable in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
lazyCookieState - Variable in class org.glassfish.grizzly.http.Cookie
 
LazyCookieState - Class in org.glassfish.grizzly.http
Lazy cookie implementation, which is based on preparsed Grizzly Buffers.
LazyCookieState() - Constructor for class org.glassfish.grizzly.http.LazyCookieState
 
LazyFileCacheKey - Class in org.glassfish.grizzly.http.server.filecache
Lazy FileCacheKey object.
lazyHolder(NullaryFunction<T>) - Static method in class org.glassfish.grizzly.utils.Holder
 
lazyIntHolder(NullaryFunction<Integer>) - Static method in class org.glassfish.grizzly.utils.Holder
 
lazyNameEquals(String) - Method in class org.glassfish.grizzly.http.Cookie
 
LC_OFFSET - Static variable in class org.glassfish.grizzly.http.server.Constants
Lower case offset.
LC_OFFSET - Static variable in class org.glassfish.grizzly.http.util.Constants
Lower case offset.
LeaderFollowerNIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in a current threads, and resumes selector thread logic in separate thread.
LENGTH_REQUIRED_411 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
lengthAttribute - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
LF - Static variable in class org.glassfish.grizzly.http.server.Constants
LF.
LF - Static variable in class org.glassfish.grizzly.http.util.Constants
LF.
lifeCycleListeners - Variable in class org.glassfish.grizzly.Context
IOEventProcessingHandler is called to notify about IOEvent processing life-cycle events like suspend, resume, complete.
lim - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
limit() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's limit.
limit(int) - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's limit.
limit() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
limit(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
limit() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
limit(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
limit() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
limit(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
linger - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
LinkedTransferQueue<E> - Class in org.glassfish.grizzly.utils
An unbounded TransferQueue based on linked nodes.
LinkedTransferQueue() - Constructor for class org.glassfish.grizzly.utils.LinkedTransferQueue
Creates an initially empty LinkedTransferQueue.
LinkedTransferQueue(Collection<? extends E>) - Constructor for class org.glassfish.grizzly.utils.LinkedTransferQueue
Creates a LinkedTransferQueue initially containing the elements of the given collection, added in traversal order of the collection's iterator.
listen() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
listen() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
listen() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
listen() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
ListFacadeFilterChain - Class in org.glassfish.grizzly.filterchain
FilterChain facade, which implements all the List related methods.
ListFacadeFilterChain(List<Filter>) - Constructor for class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
 
listIterator() - Method in class org.glassfish.grizzly.ChainProcessorSelector
listIterator(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
listIterator() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
listIterator(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
load(String) - Static method in class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
Load a class using the current {link Thread#getContextClassLoader}
load(String, ClassLoader) - Static method in class org.glassfish.grizzly.http.server.util.ClassLoaderUtil
Load a class using the provided ClassLoader
loadJmxObject(String, Object) - Static method in class org.glassfish.grizzly.monitoring.MonitoringUtils
Load JMX object class and create an instance using constructor with constructorParam.getClass() parameter.
loadJmxObject(String, Object, Class) - Static method in class org.glassfish.grizzly.monitoring.MonitoringUtils
Load JMX object class and create an instance using constructor with contructorParamType parameter.
loadProperties(LZMAEncoder.LZMAProperties) - Static method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
localAddr() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
localAddressC - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
locales - Variable in class org.glassfish.grizzly.http.server.Request
The preferred Locales associated with this Request.
localesParsed - Variable in class org.glassfish.grizzly.http.server.Request
Parse locales.
Localizable - Interface in org.glassfish.grizzly.localization
Localizable message.
Localizable - Interface in org.glassfish.tyrus.core.l10n
Localizable message.
localizableAPPLICATION_DATA_TOO_LONG(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableARGUMENT_NOT_NULL(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableBINARY_MESSAGE_HANDLER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableBINARY_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableBUFFER_OVERFLOW() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_ADD_MESSAGE_HANDLER_ERROR(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_FORBIDDEN_RETURN_TYPE(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_FORBIDDEN_WEB_SOCKET_CLOSE_PARAM(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_FORBIDDEN_WEB_SOCKET_ERROR_PARAM(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_FORBIDDEN_WEB_SOCKET_OPEN_PARAM(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_MANDATORY_PARAM_MISSING(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_CHECKER_MULTIPLE_IDENTICAL_PARAMS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCLASS_NOT_INSTANTIATED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCOMPONENT_PROVIDER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCOMPONENT_PROVIDER_THREW_EXCEPTION(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCONNECTION_HAS_BEEN_CLOSED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCONNECTION_NULL() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCONTROL_FRAME_FRAGMENTED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableCONTROL_FRAME_LENGTH() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableDATA_UNEXPECTED_LENGTH(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableDEPENDENT_CLASS_OF_PROVIDER_FORMAT_ERROR(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableDEPENDENT_CLASS_OF_PROVIDER_NOT_FOUND(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENCODING_FAILED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_ANNOTATION_NOT_FOUND(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_EXCEPTION_FROM_ON_ERROR(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_MULTIPLE_METHODS(Object, Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_MULTIPLE_SESSION_PARAM(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_UNHANDLED_EXCEPTION(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_UNKNOWN_PARAMS(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_WRONG_PARAMS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableENDPOINT_WRONG_PATH_PARAM(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableEQUIVALENT_PATHS(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableERROR_CAUGHT_WHILE_LOADING_SPI_PROVIDERS() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableEXCEPTION_CAUGHT_WHILE_LOADING_SPI_PROVIDERS() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableEXTENSION_EXCEPTION(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableFINE_GRIZZLY_ASYNCQUEUE_ERROR_NOCALLBACK_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableFINE_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_DEBUG(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableFINE_GRIZZLY_HTTP_PARAMETERS_NOEQUAL(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableFRAGMENT_INVALID_OPCODE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableFRAME_WRITE_CANCELLED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableHEADERS_MISSING() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableILLEGAL_CONFIG_SYNTAX() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableILLEGAL_PROVIDER_CLASS_NAME(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableILLEGAL_UTF_8_SEQUENCE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_DECODE_FAIL_INFO(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_INVALID_CHUNK(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINFO_GRIZZLY_HTTP_PARAMETERS_MULTIPLE_DECODING_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableINVALID_HEADER(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableINVALID_RESPONSE_CODE(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableIOEXCEPTION_CLOSE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
LocalizableMessage - Class in org.glassfish.grizzly.localization
 
LocalizableMessage(String, String, Object...) - Constructor for class org.glassfish.grizzly.localization.LocalizableMessage
 
LocalizableMessage - Class in org.glassfish.tyrus.core.l10n
 
LocalizableMessage(String, String, Object...) - Constructor for class org.glassfish.tyrus.core.l10n.LocalizableMessage
 
localizableMESSAGE_HANDLER_ALREADY_REGISTERED_BINARY() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_ALREADY_REGISTERED_PONG() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_ALREADY_REGISTERED_TEXT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_ALREADY_REGISTERED_TYPE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_DECODER_NOT_REGISTERED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_ILLEGAL_ARGUMENT(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_PARTIAL_INVALID_TYPE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_HANDLER_WHOLE_OR_PARTIAL() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableMESSAGE_TOO_LONG(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
LocalizableMessageFactory - Class in org.glassfish.grizzly.localization
 
LocalizableMessageFactory(String) - Constructor for class org.glassfish.grizzly.localization.LocalizableMessageFactory
 
LocalizableMessageFactory - Class in org.glassfish.tyrus.core.l10n
 
LocalizableMessageFactory(String) - Constructor for class org.glassfish.tyrus.core.l10n.LocalizableMessageFactory
 
localizableNO_DECODER_FOUND() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableORIGIN_NOT_VERIFIED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePARTIAL_BINARY_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePARTIAL_MESSAGE_BUFFER_OVERFLOW() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePARTIAL_TEXT_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePROVIDER_CLASS_COULD_NOT_BE_LOADED(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePROVIDER_COULD_NOT_BE_CREATED(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizablePROVIDER_NOT_FOUND(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableRSV_INCORRECTLY_SET() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSEC_KEY_INVALID_LENGTH(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSEC_KEY_INVALID_SERVER() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSEC_KEY_NULL_NOT_ALLOWED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSEND_MESSAGE_INFRAGMENT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSESSION_CLOSED_IDLE_TIMEOUT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableSEVERE_GRIZZLY_COMET_ENGINE_INVALID_NOTIFICATION_HANDLER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_CONFIG_SSL_CLASS_LOAD_FAILED_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSEVERE_GRIZZLY_CONFIG_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableSOCKET_NOT_CONNECTED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableTEXT_MESSAGE_HANDLER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableTEXT_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableUNEXPECTED_END_FRAGMENT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableUNEXPECTED_ERROR_CONNECTION_CLOSE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableUNEXPECTED_STATE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableUNHANDLED_TEXT_MESSAGE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableURI_COMPONENT_ENCODED_OCTET_INVALID_DIGIT(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableURI_COMPONENT_ENCODED_OCTET_MALFORMED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableURI_COMPONENT_INVALID_CHARACTER(Object, Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localizableWARNING_GRIZZLY_BUFFERS_OVERFLOW_EXCEPTION(Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_GENERAL_CONFIG_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_SECURE_PASSWORD_INITIALIZATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_SSL_IMPLEMENTATION_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONFIG_SSL_UNKNOWN_CIPHER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_GET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_GET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_SET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_SET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_CONNECTION_UDPMULTICASTING_EXCEPTIONE() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_FILTERCHAIN_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_GRACEFULSHUTDOWN_EXCEEDED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_GRACEFULSHUTDOWN_INTERRUPTED() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_GRACEFULSHUTDOWN_MSG(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_FILECACHE_GENERAL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_FILTER_HTTPHANDLER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_FILTER_UNEXPECTED() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_HTTPHANDLER_SERVICE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_HTTPHANDLERCHAIN_ERRORPAGE() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_REQUEST_AFTERSERVICE_NOTIFICATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_REQUEST_BODY_SKIP() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_REQUEST_POST_TOO_LARGE() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_REQUESTUTILS_SENDFILE_FAILED() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_RESPONSE_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_SERVEROUTPUTBUFFER_FILE_TRANSFER_CANCELLED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVER_SERVEROUTPUTBUFFER_FILE_TRANSFER_FAILED(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_ADD_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_REMOVE_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_DESTROYED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_INITIALIZED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_CONTEXT_LISTENER_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_INPUTSTREAM_ISREADY_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_INPUTSTREAM_SETREADLISTENER_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_NON_BLOCKING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_OUTPUTSTREAM_ISREADY_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_OUTPUTSTREAM_SETWRITELISTENER_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_BOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_UNBOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_HTTP_SEVERE_GRIZZLY_HTTP_PARAMETERS_MAX_COUNT_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_IOSTRATEGY_UNCAUGHT_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_PROCESSOR_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SELECTOR_RUNNER_NOT_IN_STOPPED_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_KEEPALIVE_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_LINGER_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_REUSEADDRESS_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_TCPNODELAY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_SOCKET_TIMEOUT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_STATE_HOLDER_CALLING_CONDITIONLISTENER_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TCPSELECTOR_HANDLER_ACCEPTCHANNEL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_IO_CANCEL_KEY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_CREATE_SELECTOR_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_MISSES_EXCEPTION(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_SELECTOR_FAILURE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_THREADPOOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_PAUSE_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_START_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_NOT_STOP_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_START_SERVER_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_TRANSPORT_UNBINDING_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
 
localizableWARNING_GRIZZLY_UTILS_STATE_HOLDER_CONDITION_LISTENER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
 
LocalizationMessages - Class in org.glassfish.tyrus.core.l10n
Defines string formatting method for each constant in the resource file
LocalizationMessages() - Constructor for class org.glassfish.tyrus.core.l10n.LocalizationMessages
 
localize(Localizable) - Method in class org.glassfish.grizzly.localization.Localizer
 
localize(Localizable) - Method in class org.glassfish.tyrus.core.l10n.Localizer
 
Localizer - Class in org.glassfish.grizzly.localization
Localizes the Localizable into a message by using a configured Locale.
Localizer() - Constructor for class org.glassfish.grizzly.localization.Localizer
 
Localizer(Locale) - Constructor for class org.glassfish.grizzly.localization.Localizer
 
Localizer - Class in org.glassfish.tyrus.core.l10n
Localizes the Localizable into a message by using a configured Locale.
Localizer() - Constructor for class org.glassfish.tyrus.core.l10n.Localizer
 
Localizer(Locale) - Constructor for class org.glassfish.tyrus.core.l10n.Localizer
 
LOCALLY_CLOSED_REASON - Static variable in class org.glassfish.grizzly.CloseReason
 
localName() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
localNameC - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
localPort - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
lock - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
lock() - Method in class org.glassfish.tyrus.core.RequestContext
Make headers and parameter map read-only.
log(String) - Method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Log a message on the Logger associated with our Container (if any)
log(String, Throwable) - Method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Log a message on the Logger associated with our Container (if any)
LogFilter - Class in org.glassfish.grizzly.utils
Simple log Filter
LogFilter() - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
LogFilter(Logger) - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
LogFilter(Logger, Level) - Constructor for class org.glassfish.grizzly.utils.LogFilter
 
logger(Class) - Static method in class org.glassfish.grizzly.Grizzly
 
LOGGER - Static variable in class org.glassfish.grizzly.http.io.OutputBuffer
 
logger - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
LoggingFormatter - Class in org.glassfish.grizzly.utils
Format the record to include the Thread that logged the record.
LoggingFormatter() - Constructor for class org.glassfish.grizzly.utils.LoggingFormatter
 
LogMessages - Class in org.glassfish.grizzly.localization
Defines string formatting method for each constant in the resource file
LogMessages() - Constructor for class org.glassfish.grizzly.localization.LogMessages
 
longToBuffer(long, byte[]) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
Converts the specified long as a string representation to the provided byte buffer.
longToBuffer(long, Buffer) - Static method in class org.glassfish.grizzly.http.util.HttpUtils
Converts the specified long as a string representation to the provided buffer.
lookup(String) - Method in interface org.glassfish.grizzly.http.server.naming.NamingContext
Retrieves the named object.
lookupCharset(String) - Static method in class org.glassfish.grizzly.utils.Charsets
Lookup a Charset by name.
lookupFileCache(FilterChainContext) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
LZMAContentEncoding - Class in org.glassfish.grizzly.http
 
LZMAContentEncoding() - Constructor for class org.glassfish.grizzly.http.LZMAContentEncoding
 
LZMAContentEncoding(EncodingFilter) - Constructor for class org.glassfish.grizzly.http.LZMAContentEncoding
 
LZMADecoder - Class in org.glassfish.grizzly.compression.lzma
 
LZMADecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
LZMADecoder.LZMAInputState - Class in org.glassfish.grizzly.compression.lzma
 
LZMADecoder.LZMAInputState() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
LZMAEncoder - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
LZMAEncoder(LZMAEncoder.LZMAProperties) - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
LZMAEncoder.LZMAOutputState - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder.LZMAOutputState() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
LZMAEncoder.LZMAProperties - Class in org.glassfish.grizzly.compression.lzma
 
LZMAEncoder.LZMAProperties() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
LZMAEncoder.LZMAProperties(int, int, int, int, int, int, int) - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
LZMAFilter - Class in org.glassfish.grizzly.compression.lzma
 
LZMAFilter() - Constructor for class org.glassfish.grizzly.compression.lzma.LZMAFilter
 

M

main(String[]) - Static method in class org.glassfish.grizzly.Grizzly
 
main(String[]) - Static method in class org.glassfish.grizzly.http.util.FastDateFormat
 
main(String[]) - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
main(String[]) - Static method in class org.glassfish.grizzly.utils.LoggingFormatter
Example to test the com.glassfish.grizzly.utils.LoggingFormatter You need to include this parameter in the command line -Djava.util.logging.config.file=myfile
makeCancellableFuture(Connection) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
makeContentLengthHeader(long) - Method in class org.glassfish.grizzly.http.HttpHeader
Makes sure content-length header is present.
makeIOException(Throwable) - Static method in class org.glassfish.grizzly.utils.Exceptions
Wrap the given Throwable by IOException.
makeTransferEncodingHeader(String) - Method in class org.glassfish.grizzly.http.HttpHeader
Makes sure transfer-encoding header is present.
makeUpgradeHeader() - Method in class org.glassfish.grizzly.http.HttpHeader
 
managedWorkerPool - Variable in class org.glassfish.grizzly.AbstractTransport
 
managementObject - Variable in class org.glassfish.grizzly.http.server.HttpServer
 
map(DataChunk, DataChunk, MappingData) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Map the specified host name and URI, mutating the given mapping data.
map(HttpRequestPacket, DataChunk, MappingData) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Map the specified host name and URI, mutating the given mapping data.
map(MessageBytes, MappingData) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Map the specified URI relative to the context, mutating the given mapping data.
mapName(DataChunk, MappingData) - Method in interface org.glassfish.grizzly.http.server.util.DispatcherHelper
 
mapPath(HttpRequestPacket, DataChunk, MappingData) - Method in interface org.glassfish.grizzly.http.server.util.DispatcherHelper
 
Mapper - Class in org.glassfish.grizzly.http.server.util
Mapper, which implements the servlet API mapping rules (which are derived from the HTTP rules).
Mapper() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper
 
Mapper.Context - Class in org.glassfish.grizzly.http.server.util
 
Mapper.Context() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper.Context
 
Mapper.ContextList - Class in org.glassfish.grizzly.http.server.util
 
Mapper.ContextList() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper.ContextList
 
Mapper.Host - Class in org.glassfish.grizzly.http.server.util
 
Mapper.Host() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper.Host
 
Mapper.MapElement - Class in org.glassfish.grizzly.http.server.util
 
Mapper.MapElement() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper.MapElement
 
Mapper.Wrapper - Class in org.glassfish.grizzly.http.server.util
 
Mapper.Wrapper() - Constructor for class org.glassfish.grizzly.http.server.util.Mapper.Wrapper
 
MappingData - Class in org.glassfish.grizzly.http.server.util
Mapping data.
MappingData() - Constructor for class org.glassfish.grizzly.http.server.util.MappingData
 
mapUriWithSemicolon(HttpRequestPacket, DataChunk, MappingData, int) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Maps the decodedURI to the corresponding HttpHandler, considering that URI may have a semicolon with extra data followed, which shouldn't be a part of mapping process.
mapUriWithSemicolon(DataChunk, DataChunk, MappingData, int) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Maps the decodedURI to the corresponding HttpHandler, considering that URI may have a semicolon with extra data followed, which shouldn't be a part of mapping process.
mark() - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's mark at its position.
mark(int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Supported with binary and character data.
mark() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
mark() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
mark - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
mark() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
markCancelled(int) - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
Marks Response as cancelled, if expectedModCount corresponds to the current modCount.
markCancelled() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
Deprecated. 
markForRecycle(boolean) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Deprecated. 
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
markForRecycle(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
markResumed() - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
Marks Response as resumed, but doesn't resume associated FilterChainContext invocation.
markSupported() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Only supported with binary data.
mask(boolean) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Currently not used.
MASK_SIZE - Static variable in class org.glassfish.tyrus.core.ProtocolHandler
RFC 6455
maskingKey(int) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set masking key.
match(CharSequence) - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Match against the pattern.
match(CharSequence, List<String>) - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Match against the pattern.
match(CharSequence, List<String>, Map<String, String>) - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Match against the pattern.
match(CharSequence, Map<String, String>) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Match a URI against the template.
match(CharSequence, List<String>) - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Match a URI against the template.
Match - Class in org.glassfish.tyrus.core.uri
Defines a match on an endpoint.
matchesMethod(String) - Method in class org.glassfish.grizzly.http.Method
 
MAX_AGE_IN_SECONDS - Static variable in class org.glassfish.grizzly.http.server.Constants
 
MAX_CACHE_ENTRIES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
MAX_LARGE_FILE_CACHE_SIZE - Static variable in class org.glassfish.grizzly.http.server.Constants
 
MAX_NUM_HEADERS_DEFAULT - Static variable in class org.glassfish.grizzly.http.util.MimeHeaders
 
MAX_NUM_HEADERS_UNBOUNDED - Static variable in class org.glassfish.grizzly.http.util.MimeHeaders
 
MAX_RECEIVE_BUFFER_SIZE - Static variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
MAX_REQUEST_PARAMETERS - Static variable in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
maxAge - Variable in class org.glassfish.grizzly.http.Cookie
 
maxAsyncWriteQueueSize - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
maxBufferSize - Variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
 
maxHeadersSize - Variable in class org.glassfish.grizzly.http.HttpCodecFilter
 
maxNumHeaders(int) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Sets the maximum number of headers allowed.
maxPendingBytes - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
maxPendingBytes - Variable in class org.glassfish.grizzly.ssl.SSLFilter
 
maxPendingBytesPerConnection - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
maxPoolSize - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
maxQueuedTasks - Variable in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
maxSmallBufferSize - Variable in class org.glassfish.grizzly.memory.ByteBufferManager
 
maxWriteReentrants - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
maybeQuote2(int, StringBuilder, String, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
Quotes values using rules that vary depending on Cookie version.
maybeQuote2(int, StringBuilder, String, boolean, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
maybeQuote2(int, StringBuilder, String, String, boolean, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
maybeQuote2(int, Buffer, String, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
Quotes values using rules that vary depending on Cookie version.
maybeQuote2(int, Buffer, String, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
maybeQuote2(int, Buffer, String, String, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
MBEAN_REGISTRY_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which the managed bean Registry will be stored for privileged contexts (if enabled).
MBEAN_SERVER_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which the MBeanServer will be stored for privileged contexts (if enabled).
memoryManager - Variable in class org.glassfish.grizzly.AbstractTransport
Transport MemoryManager
MemoryManager<E extends Buffer> - Interface in org.glassfish.grizzly.memory
MemoryManager, responsible for allocating and releasing memory, required during application runtime.
memoryManager - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
memoryManager - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
memoryManager - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
MemoryProbe - Interface in org.glassfish.grizzly.memory
MemoryManager monitoring probe.
MemoryProbe.Adapter - Class in org.glassfish.grizzly.memory
MemoryProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
MemoryProbe.Adapter() - Constructor for class org.glassfish.grizzly.memory.MemoryProbe.Adapter
 
MemoryUtils - Class in org.glassfish.grizzly.memory
Class has useful methods to simplify the work with Buffers.
MemoryUtils() - Constructor for class org.glassfish.grizzly.memory.MemoryUtils
 
message - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
MESSAGE_HANDLER_ALREADY_REGISTERED_BINARY() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Binary MessageHandler already registered.
MESSAGE_HANDLER_ALREADY_REGISTERED_PONG() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Pong MessageHandler already registered.
MESSAGE_HANDLER_ALREADY_REGISTERED_TEXT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Text MessageHandler already registered.
MESSAGE_HANDLER_ALREADY_REGISTERED_TYPE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
MessageHandler for type: {0} already registered.
MESSAGE_HANDLER_DECODER_NOT_REGISTERED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Decoder for type: {0} has not been registered.
MESSAGE_HANDLER_ILLEGAL_ARGUMENT(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Illegal MessageHandler argument value: {0}.
MESSAGE_HANDLER_PARTIAL_INVALID_TYPE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Partial MessageHandler can''t be of type: {0}.
MESSAGE_HANDLER_WHOLE_OR_PARTIAL() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
MessageHandler must implement MessageHandler.Whole or MessageHandler.Partial.
MESSAGE_TOO_LONG(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Message too long; allowed message size is {0} bytes.
MessageBytes - Class in org.glassfish.grizzly.http.util
This class is used to represent a subarray of bytes in an HTTP message.
MessageBytes() - Constructor for class org.glassfish.grizzly.http.util.MessageBytes
Deprecated.
Use static newInstance() in order to allow future hooks.
MessageBytes.MessageBytesFactory - Class in org.glassfish.grizzly.http.util
 
MessageBytes.MessageBytesFactory() - Constructor for class org.glassfish.grizzly.http.util.MessageBytes.MessageBytesFactory
 
MessageCloner<E> - Interface in org.glassfish.grizzly.asyncqueue
Cloner, which will be called by AsyncQueueWriter, when message could not be written directly, and will be added to the queue.
MessageHandler - Interface in javax.websocket
Developers implement MessageHandlers in order to receive incoming messages during a web socket conversation.
MessageHandler.Partial<T> - Interface in javax.websocket
This kind of handler is notified by the implementation as it becomes ready to deliver parts of a whole message.
MessageHandler.Whole<T> - Interface in javax.websocket
This kind of handler is notified by the container on arrival of a complete message.
method - Variable in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
method(Method) - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Set the HTTP request method.
method(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Set the HTTP request method.
Method - Class in org.glassfish.grizzly.http
Predefined HTTP methods
Method.PayloadExpectation - Enum in org.glassfish.grizzly.http
 
METHOD_NOT_ALLOWED_405 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
methodInstanceToString(Object, Method) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Create a string representation of a method and an instance whose class implements the method.
methodString - Variable in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
mimeHeaders - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
MimeHeaders - Class in org.glassfish.grizzly.http.util
Memory-efficient repository for Mime Headers.
MimeHeaders() - Constructor for class org.glassfish.grizzly.http.util.MimeHeaders
Creates a new MimeHeaders object using a default buffer size.
MimeHeaders.MaxHeaderCountExceededException - Exception in org.glassfish.grizzly.http.util
 
MimeHeaders.MaxHeaderCountExceededException() - Constructor for exception org.glassfish.grizzly.http.util.MimeHeaders.MaxHeaderCountExceededException
 
MimeHeadersPacket - Interface in org.glassfish.grizzly.http
Common interface for HttpPackets, which contain mimeheaders.
MimeType - Class in org.glassfish.grizzly.http.util
Hardcoded mime-type supported by default.
MimeType() - Constructor for class org.glassfish.grizzly.http.util.MimeType
 
mm - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
modifyHandshake(ServerEndpointConfig, HandshakeRequest, HandshakeResponse) - Method in class javax.websocket.server.ServerEndpointConfig.Configurator
Called by the container after it has formulated a handshake response resulting from a well-formed handshake request.
Monitorable - Interface in org.glassfish.grizzly.http.server.jmxbase
Interface that allows arbitrary entities to provide a JmxObject that can be registered with the org.glassfish.grizzly.monitoring.jmx.GrizzlyJmxManager.
MonitoringAware<E> - Interface in org.glassfish.grizzly.monitoring
General interface for the objects, which could be monitored during the lifecycle.
monitoringConfig - Variable in class org.glassfish.grizzly.http.HttpCodecFilter
File cache probes
monitoringConfig - Variable in class org.glassfish.grizzly.http.KeepAlive
Keep alive probes
monitoringConfig - Variable in class org.glassfish.grizzly.http.server.filecache.FileCache
File cache probes
monitoringConfig - Variable in class org.glassfish.grizzly.http.server.HttpServerFilter
Web server probes
monitoringConfig - Variable in class org.glassfish.grizzly.memory.AbstractMemoryManager
Basic monitoring support.
monitoringConfig - Variable in class org.glassfish.grizzly.memory.PooledMemoryManager
Basic monitoring support.
MonitoringConfig<E> - Interface in org.glassfish.grizzly.monitoring
General monitoring configuration interface.
monitoringConfig - Variable in class org.glassfish.grizzly.nio.NIOConnection
Connection probes
monitoringConfig - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
ThreadPool probes
MonitoringUtils - Class in org.glassfish.grizzly.monitoring
The class, which contains utility methods for monitoring support.
MonitoringUtils() - Constructor for class org.glassfish.grizzly.monitoring.MonitoringUtils
 
moveBlock() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
MOVED_PERMANENTLY_301 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
movePos() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
movePos() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
multiBufferWindow - Variable in class org.glassfish.grizzly.streams.BufferedOutput
 
MULTIPLE_CHOICES_300 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
MultivaluedHashMap<K,V> - Class in org.glassfish.tyrus.core.uri.internal
A hash table based implementation of MultivaluedMap interface.
MultivaluedHashMap() - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedHashMap
Constructs an empty multivalued hash map with the default initial capacity (16) and the default load factor (0.75).
MultivaluedHashMap(int) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedHashMap
Constructs an empty multivalued hash map with the specified initial capacity and the default load factor (0.75).
MultivaluedHashMap(int, float) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedHashMap
Constructs an empty multivalued hash map with the specified initial capacity and load factor.
MultivaluedHashMap(MultivaluedMap<? extends K, ? extends V>) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedHashMap
Constructs a new multivalued hash map with the same mappings as the specified MultivaluedMap.
MultivaluedHashMap(Map<? extends K, ? extends V>) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedHashMap
Constructs a new multivalued hash map with the same mappings as the specified single-valued Map.
MultivaluedMap<K,V> - Interface in org.glassfish.tyrus.core.uri.internal
A map of key-values pairs.
MultivaluedStringMap - Class in org.glassfish.tyrus.core.uri.internal
An implementation of MultivaluedMap where keys and values are instances of String.
MultivaluedStringMap(MultivaluedMap<? extends String, ? extends String>) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
MultivaluedStringMap(int, float) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
MultivaluedStringMap(int) - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 
MultivaluedStringMap() - Constructor for class org.glassfish.tyrus.core.uri.internal.MultivaluedStringMap
 

N

name - Variable in class org.glassfish.grizzly.AbstractTransport
Transport name
name() - Method in class org.glassfish.grizzly.attributes.Attribute
Return attribute name, which is used as attribute key on non-indexed AttributeHolders.
name - Variable in class org.glassfish.grizzly.http.Cookie
 
NAME - Static variable in class org.glassfish.grizzly.http.GZipContentEncoding
 
NAME - Static variable in class org.glassfish.grizzly.http.LZMAContentEncoding
 
name - Variable in class org.glassfish.grizzly.http.server.GrizzlyPrincipal
The username of the user represented by this Principal.
name - Variable in class org.glassfish.grizzly.http.server.util.Mapper.MapElement
 
name - Variable in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
name - Variable in class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
name - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
name2Attribute - Variable in class org.glassfish.grizzly.attributes.DefaultAttributeBuilder
 
NAMED_DISPATCHER_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we store the servlet name on a named dispatcher request.
names() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Returns an enumeration of strings representing the header field names.
NamingContext - Interface in org.glassfish.grizzly.http.server.naming
This interface represents a naming context, which consists of a set of name-to-object bindings.
NamingException - Exception in org.glassfish.grizzly.http.server.naming
This is the superclass of all exceptions thrown by operations in the Context and DirContext interfaces.
NamingException(String) - Constructor for exception org.glassfish.grizzly.http.server.naming.NamingException
 
NamingException(String, Throwable) - Constructor for exception org.glassfish.grizzly.http.server.naming.NamingException
 
NamingException(Throwable) - Constructor for exception org.glassfish.grizzly.http.server.naming.NamingException
 
NEED_HANDSHAKE_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
NEED_HANDSHAKE_ERROR - Static variable in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
needClientAuth - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Require client Authentication.
nesting - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
nesting - Variable in class org.glassfish.grizzly.http.server.util.Mapper.ContextList
 
NetworkListener - Class in org.glassfish.grizzly.http.server
 
NetworkListener(String) - Constructor for class org.glassfish.grizzly.http.server.NetworkListener
Constructs a new NetworkListener using the specified name.
NetworkListener(String, boolean) - Constructor for class org.glassfish.grizzly.http.server.NetworkListener
Constructs a new NetworkListener using the specified name, which, depending on isBindToInherited will or will not be bound to an inherited Channel.
NetworkListener(String, String) - Constructor for class org.glassfish.grizzly.http.server.NetworkListener
Constructs a new NetworkListener using the specified name and host.
NetworkListener(String, String, int) - Constructor for class org.glassfish.grizzly.http.server.NetworkListener
Constructs a new NetworkListener using the specified name, host, and port.
NetworkListener(String, String, PortRange) - Constructor for class org.glassfish.grizzly.http.server.NetworkListener
Constructs a new NetworkListener using the specified name, host, and port.
newBuffer() - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
Construct CompositeBuffer.
newBuffer(MemoryManager) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(MemoryManager, Buffer...) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(MemoryManager, Buffer[], boolean) - Static method in class org.glassfish.grizzly.memory.CompositeBuffer
 
newBuffer(int) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
newBuffer(int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
newBuffer(int) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
newContentType(String) - Static method in class org.glassfish.grizzly.http.util.ContentType
Creates a ContentType wrapper over a String content-type representation.
newContentType(String, String) - Static method in class org.glassfish.grizzly.http.util.ContentType
Creates a ContentType wrapper over the passed mime-type and character encoding.
newDecoder() - Method in class org.glassfish.tyrus.core.StrictUtf8
 
newEncoder() - Method in class org.glassfish.tyrus.core.StrictUtf8
 
newHeaderValue(String) - Static method in class org.glassfish.grizzly.http.util.HeaderValue
Creates a HeaderValue wrapper over a String header value representation.
newHttpStatus(int, String) - Static method in class org.glassfish.grizzly.http.util.HttpStatus
 
newInstance(FilterChainContext, AttributeStorage, OutputSink, Closeable) - Static method in class org.glassfish.grizzly.http.HttpContext
 
newInstance() - Static method in class org.glassfish.grizzly.http.util.DataChunk
 
newInstance(ByteChunk, BufferChunk, CharChunk, String) - Static method in class org.glassfish.grizzly.http.util.DataChunk
 
newInstance() - Method in class org.glassfish.grizzly.http.util.MessageBytes.MessageBytesFactory
 
newInstance() - Static method in class org.glassfish.grizzly.http.util.MessageBytes
Construct a new MessageBytes instance
newInstance() - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
newInstance() - Static method in class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
newSelector(SelectorProvider) - Static method in class org.glassfish.grizzly.nio.Selectors
Creates new Selector using passed SelectorProvider.
newSettableContentType() - Static method in class org.glassfish.grizzly.http.util.ContentType
 
NextAction - Interface in org.glassfish.grizzly.filterchain
The interface defines the instruction for a FilterChain, how it should continue filter chain execution.
nextElement() - Method in class org.glassfish.grizzly.http.server.util.Enumerator
Returns the next element of this enumeration if this enumeration has at least one more element to provide.
nextFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
NIOChannelDistributor - Interface in org.glassfish.grizzly.nio
 
nioChannelDistributor - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
nioChannelDistributor - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
NIOConnection - Class in org.glassfish.grizzly.nio
Common Connection implementation for Java NIO Connections.
NIOConnection(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.NIOConnection
 
NIOInputStream - Class in org.glassfish.grizzly.http.io
Stream implementation to read binary request content.
NIOInputStream() - Constructor for class org.glassfish.grizzly.http.io.NIOInputStream
 
NIOOutputStream - Class in org.glassfish.grizzly.http.io
Stream implementation for writing binary content to an HTTP user-agent.
NIOOutputStream() - Constructor for class org.glassfish.grizzly.http.io.NIOOutputStream
 
NIOReader - Class in org.glassfish.grizzly.http.io
Character stream implementation used to read character-based request content.
NIOReader() - Constructor for class org.glassfish.grizzly.http.io.NIOReader
 
NIOTransport - Class in org.glassfish.grizzly.nio
 
NIOTransport(String) - Constructor for class org.glassfish.grizzly.nio.NIOTransport
 
NIOTransportBuilder<T extends NIOTransportBuilder> - Class in org.glassfish.grizzly
This builder is responsible for creating NIOTransport implementations as well as providing basic configuration for IOStrategies and thread pools.
NIOTransportBuilder(Class<? extends NIOTransport>) - Constructor for class org.glassfish.grizzly.NIOTransportBuilder
Constructs a new NIOTransport using the given transportClass and IOStrategy.
NIOWriter - Class in org.glassfish.grizzly.http.io
Stream implementation for writing character content to an HTTP user-agent.
NIOWriter() - Constructor for class org.glassfish.grizzly.http.io.NIOWriter
 
NO_CONTENT_204 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
NO_DECODER_FOUND() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
No decoder found.
NO_FILTER_INDEX - Static variable in class org.glassfish.grizzly.filterchain.FilterChainContext
 
NON_AUTHORATIVE_INFORMATION_203 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
NoOpByteArrayCoder - Class in org.glassfish.tyrus.core.coder
Encoder and Decoder implementation for byte array.
NoOpByteArrayCoder() - Constructor for class org.glassfish.tyrus.core.coder.NoOpByteArrayCoder
 
NoOpByteBufferCoder - Class in org.glassfish.tyrus.core.coder
Encoder and Decoder implementation for ByteBuffer.
NoOpByteBufferCoder() - Constructor for class org.glassfish.tyrus.core.coder.NoOpByteBufferCoder
 
NoOpTextCoder - Class in org.glassfish.tyrus.core.coder
 
NoOpTextCoder() - Constructor for class org.glassfish.tyrus.core.coder.NoOpTextCoder
 
normalize() - Method in enum org.glassfish.grizzly.http.server.CompressionLevel
Deprecated.
 
normalize(MessageBytes) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Normalize URI.
normalize(DataChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
Normalize URI.
normalizeBuffer(BufferChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
 
normalizeBytes(ByteChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
 
normalizeChars(CharChunk) - Static method in class org.glassfish.grizzly.http.util.HttpRequestURIDecoder
 
NOT_ACCEPTABLE_406 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
NOT_FOUND_404 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
NOT_IMPLEMENTED_501 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
NOT_LOCALIZABLE - Static variable in interface org.glassfish.grizzly.localization.Localizable
Special constant that represents a message that is not localizable.
NOT_LOCALIZABLE - Static variable in interface org.glassfish.tyrus.core.l10n.Localizable
Special constant that represents a message that is not localizable.
NOT_MODIFIED_304 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
Note<E> - Class in org.glassfish.grizzly.http
The Note value associated with HttpRequestPacket.
NOTIFICATION_CLOSED_COMPLETE - Static variable in class org.glassfish.grizzly.nio.NIOConnection
 
NOTIFICATION_INITIALIZED - Static variable in class org.glassfish.grizzly.nio.NIOConnection
 
notifyAvailable(ReadHandler) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Installs a ReadHandler that will be notified when any data becomes available to read without blocking.
notifyAvailable(ReadHandler, int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Installs a ReadHandler that will be notified when the specified amount of data is available to be read without blocking.
notifyAvailable(ReadHandler) - Method in interface org.glassfish.grizzly.InputSource
Notify the specified ReadHandler when any number of bytes or characters can be read without blocking.
notifyAvailable(ReadHandler, int) - Method in interface org.glassfish.grizzly.InputSource
Notify the specified ReadHandler when the number of bytes that can be read without blocking is greater or equal to the specified size.
notifyAvailable(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyAvailable(int, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader has required amount of bytes available for reading reading.
notifyCancel(FutureImpl<R>, CompletionHandler) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler via the cancellation notification.
notifyCanWrite(WriteHandler, int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Deprecated.
the length parameter will be ignored. Please use OutputBuffer.notifyCanWrite(org.glassfish.grizzly.WriteHandler).
notifyCanWrite(WriteHandler) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
notifyCanWrite(WriteHandler) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Instructs the OutputSink to invoke the provided WriteHandler when it is possible to write more bytes (or characters).
notifyCanWrite(WriteHandler, int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Deprecated.
notifyCanWrite(WriteHandler) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Instructs the OutputSink to invoke the provided WriteHandler when it is possible to write more bytes (or characters).
notifyCanWrite(WriteHandler, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Deprecated.
notifyCanWrite(WriteHandler) - Method in interface org.glassfish.grizzly.OutputSink
Instructs the OutputSink to invoke the provided WriteHandler when it is possible to write more bytes (or characters).
notifyCanWrite(WriteHandler, int) - Method in interface org.glassfish.grizzly.OutputSink
Deprecated.
the length parameter will be ignored. Pls. use OutputSink.notifyCanWrite(org.glassfish.grizzly.WriteHandler).
notifyChangedExcept(Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
 
notifyComplete() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
notifyCompleteAndRecycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
notifyCompleted(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
notifyCompleted(CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyCondition(Condition) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyCondition(Condition, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.Input
 
notifyCondition(Condition, CompletionHandler<Integer>) - Method in class org.glassfish.grizzly.streams.StreamInput
 
notifyCondition(Condition) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyCondition(Condition, CompletionHandler<Integer>) - Method in interface org.glassfish.grizzly.streams.StreamReader
Method returns Future, using which it's possible check if StreamReader meets specific Condition.
notifyConditionListeners() - Method in class org.glassfish.grizzly.utils.StateHolder
 
notifyConnectionError(Throwable) - Method in interface org.glassfish.grizzly.Connection
Method gets invoked, when error occur during the Connection lifecycle.
notifyConnectionError(Throwable) - Method in class org.glassfish.grizzly.nio.NIOConnection
Method gets invoked, when error occur during the Connection lifecycle.
notifyDirectUpdate() - Method in class org.glassfish.grizzly.http.util.BufferChunk
Notify the Chunk that its content is going to be changed directly
notifyDirectUpdate() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Notify the Chunk that its content is going to be changed directly
notifyDirectUpdate() - Method in class org.glassfish.grizzly.http.util.CharChunk
Notify the Chunk that its content is going to be changed directly
notifyDirectUpdate() - Method in class org.glassfish.grizzly.http.util.DataChunk
Notify the Chunk that its content is going to be changed directly
notifyDownstream(FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyDownstream(FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyException(ExceptionHandler.Severity, Throwable) - Method in interface org.glassfish.grizzly.utils.ExceptionHandler
 
notifyFailure(Throwable) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
notifyFailure(CompletionHandler<Integer>, Throwable) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
notifyFailure(CompletionHandler<Integer>, Throwable) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
notifyFailure(FutureImpl<R>, CompletionHandler, Throwable) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler using the passed error
notifyHandshakeComplete(Connection<?>, SSLEngine) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
notifyHandshakeComplete(Connection<?>, SSLEngine) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
notifyHandshakeFailed(Connection, Throwable) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
notifyHandshakeFailed(Connection, Throwable) - Method in class org.glassfish.grizzly.ssl.SSLFilter
 
notifyHandshakeStart(Connection) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
notifyHaveResult() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Notify blocked listeners threads about operation completion.
notifyIncomplete() - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
notifyIOEventDisabled(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event disabled event.
notifyIOEventEnabled(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event enabled event.
notifyIOEventReady(NIOConnection, IOEvent) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the IO Event ready event.
notifyProbesAccept(NIOConnection, NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the accept event.
notifyProbesBeforePause(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the before-pause event.
notifyProbesBeforeResume(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the before-resume event.
notifyProbesBeforeStart(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the before-start event.
notifyProbesBeforeStop(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the before-stop event.
notifyProbesBind(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the bind event.
notifyProbesClose(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the close event.
notifyProbesConfigChanged(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the config changed event.
notifyProbesConnect(NIOConnection) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the connect event.
notifyProbesConnectionAccepted(KeepAlive, Connection) - Static method in class org.glassfish.grizzly.http.KeepAlive
Notify registered KeepAliveProbes about the "keep-alive connection accepted" event.
notifyProbesEntryAdded(FileCache, FileCacheEntry) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
Notify registered FileCacheProbes about the "entry added" event.
notifyProbesEntryHit(FileCache, FileCacheEntry) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
Notify registered FileCacheProbes about the "entry hit event.
notifyProbesEntryMissed(FileCache, HttpRequestPacket) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
Notify registered FileCacheProbes about the "entry missed" event.
notifyProbesEntryRemoved(FileCache, FileCacheEntry) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
Notify registered FileCacheProbes about the "entry removed" event.
notifyProbesError(FileCache, Throwable) - Static method in class org.glassfish.grizzly.http.server.filecache.FileCache
Notify registered FileCacheProbes about the error.
notifyProbesError(NIOConnection, Throwable) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the error.
notifyProbesError(NIOTransport, Throwable) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the error.
notifyProbesHit(KeepAlive, Connection, int) - Static method in class org.glassfish.grizzly.http.KeepAlive
Notify registered KeepAliveProbes about the "keep-alive connection hit" event.
notifyProbesPause(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the pause event.
notifyProbesPause(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the pause event.
notifyProbesRead(NIOConnection, Buffer, int) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the read event.
notifyProbesRefused(KeepAlive, Connection) - Static method in class org.glassfish.grizzly.http.KeepAlive
Notify registered KeepAliveProbes about the "keep-alive connection refused" event.
notifyProbesResume(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the resume event.
notifyProbesStart(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the start event.
notifyProbesStop(AbstractTransport) - Static method in class org.glassfish.grizzly.AbstractTransport
Notify registered TransportProbes about the stop event.
notifyProbesStop(NIOTransport) - Static method in class org.glassfish.grizzly.nio.NIOTransport
Notify registered TransportProbes about the stop event.
notifyProbesTimeout(KeepAlive, Connection) - Static method in class org.glassfish.grizzly.http.KeepAlive
Notify registered KeepAliveProbes about the "keep-alive connection timeout" event.
notifyProbesWrite(NIOConnection, Buffer, long) - Static method in class org.glassfish.grizzly.nio.NIOConnection
Notify registered ConnectionProbes about the write event.
notifyReady() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
notifyReady() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
notifyResult(FutureImpl<R>, CompletionHandler<R>, R) - Static method in class org.glassfish.grizzly.utils.Futures
Complete passed FutureImpl and CompletionHandler using the passed result object.
notifyTransportError(Throwable) - Method in class org.glassfish.grizzly.nio.NIOTransport
Method gets invoked, when error occur during the Transport lifecycle.
notifyTransportError(Throwable) - Method in interface org.glassfish.grizzly.Transport
Method gets invoked, when error occur during the Transport lifecycle.
notifyUpstream(FilterChainEvent) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyUpstream(FilterChainEvent, CompletionHandler<FilterChainContext>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
notifyWhenConditionMatchState(Condition, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will match the condition.
notifyWhenStateIsEqual(E, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will be equal to passed one.
notifyWhenStateIsNotEqual(E, CompletionHandler<E>) - Method in class org.glassfish.grizzly.utils.StateHolder
Register listener, which will be notified, when state will become not equal to passed one.
notifyWritePossible(Connection<L>, WriteHandler, int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Deprecated.
the size parameter will be ignored, use {@link #notifyWritePossible(org.glassfish.grizzly.Connection, org.glassfish.grizzly.WriteHandler) instead.
notifyWritePossible(WriteHandler) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
notifyWritePossible(WriteHandler, int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
notifyWritePossible(Connection<SocketAddress>, WriteHandler, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Deprecated.
notifyWritePossible(Connection<SocketAddress>, WriteHandler) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
notifyWritePossible(Connection, WriteHandler) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Registers WriteHandler, which will be notified ones at least one byte can be written.
notifyWritePossible(Connection<L>, WriteHandler) - Method in interface org.glassfish.grizzly.Writer
Registers WriteHandler, which will be notified ones at least one byte can be written.
nowPos64 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
NullaryFunction<T> - Interface in org.glassfish.grizzly.attributes
Deprecated.
NullaryFunction<T> - Interface in org.glassfish.grizzly.utils
General initializer interface.

O

object - Variable in class org.glassfish.grizzly.http.server.util.Mapper.MapElement
 
ObjectPool<E extends PoolableObject> - Interface in org.glassfish.grizzly.utils
Basic interface for object pool implementations
objectToString(Object) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Create a string representation of an object.
obtainArrayCopy() - Method in class org.glassfish.grizzly.utils.ArraySet
Get the copy of the underlying array.
obtainContext(Connection) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Creates Context
obtainContext(Connection) - Method in interface org.glassfish.grizzly.Processor
Creates Context
obtainContext(Connection) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
obtainCurrentElement() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Get the current processing task, if the current in not set, take the task from the queue.
obtainCurrentElementAndReserve() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Gets the current processing task and reserves its place.
obtainFilterChainContext(Connection) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
 
obtainFilterChainContext(Connection, int, int, int) - 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 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
 
obtainMappingData() - Method in class org.glassfish.grizzly.http.server.Request
 
obtainMemoryManager(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
obtainPostponedTasks() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
obtainProcessor(IOEvent, Connection) - Method in class org.glassfish.grizzly.AbstractTransport
Gets the default Processor, which will process Transport Connections I/O events in case, if Connection doesn't have own Processor preferences.
obtainProcessor(IOEvent) - Method in interface org.glassfish.grizzly.Connection
Gets the Processor, which will process Connection I/O event.
obtainProcessor(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
obtainProcessor(IOEvent, Connection) - Method in interface org.glassfish.grizzly.Transport
Gets the default Processor, which will process Transport Connections I/O events in case, if Connection doesn't have own Processor preferences.
obtainProcessorState(Processor, NullaryFunction<E>) - Method in interface org.glassfish.grizzly.Connection
Returns the Processor state associated with this Connection.
obtainProcessorState(Processor, NullaryFunction<E>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
obtainStateObject(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
offer(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Add the new task into the task queue.
offer(Selector) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
offer(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offer(E) - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
offerToTaskQueue(NIOConnection, AsyncWriteQueueRecord, TaskQueue<AsyncWriteQueueRecord>) - Static method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
offerToTaskQueue(NIOConnection, AsyncWriteQueueRecord, TaskQueue<AsyncWriteQueueRecord>) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
offset - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
offset - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
OK_200 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
OLD_COOKIE_FORMAT - Static variable in class org.glassfish.grizzly.http.util.CookieUtils
 
onAccept(Connection, WritableMessage) - Method in interface org.glassfish.grizzly.asyncqueue.PushBackHandler
Deprecated.
The method is invoked once message is accepted by Writer.
onAccept() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
Method will be called by framework, when async accept will be ready
onAcceptEvent(Connection, Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when server side connection gets accepted.
onAcceptEvent(Connection, Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when server side connection gets accepted.
onAdded(FilterChain) - Method in class org.glassfish.grizzly.filterchain.BaseFilter
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.utils.LogFilter
 
onAfterService(Request) - Method in interface org.glassfish.grizzly.http.server.AfterServiceListener
The method will be called once the Request processing will be completed.
onAfterService() - Method in class org.glassfish.grizzly.http.server.Request
 
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.
onBeforeServiceEvent(HttpServerFilter, Connection, Request, HttpHandler) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
onBeforeServiceEvent(HttpServerFilter, Connection, Request, HttpHandler) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
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.
onBroadcast(String) - Method in interface org.glassfish.tyrus.core.cluster.BroadcastListener
Invoked when received request to broadcast text message.
onBroadcast(byte[]) - Method in interface org.glassfish.tyrus.core.cluster.BroadcastListener
Invoked when received request to broadcast binary data.
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(Session, CloseReason) - Method in class javax.websocket.Endpoint
This method is called immediately prior to the session with the remote peer being closed.
OnClose - Annotation Type in javax.websocket
This method level annotation can be used to decorate a Java method that wishes to be called when a web socket session is closing.
onClose(Connection) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClose() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
onClose(Throwable) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
onClose(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClose(Connection) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Callback method, which is called, when Connection has been closed, to let processor release a connection associated resources.
onClose(Session, CloseReason) - Method in class org.glassfish.tyrus.core.AnnotatedEndpoint
 
onClose() - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on session close event.
onClose(CloseReason) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on session close event.
onClose(TyrusWebSocket, CloseReason) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection to the given remote endpoint has just closed.
onClose(CloseReason) - Method in interface org.glassfish.tyrus.core.TyrusEndpointWrapper.OnCloseListener
onClose(CloseFrame) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when the remote end-point sent a closing frame.
onClosed(T, C) - Method in interface org.glassfish.grizzly.CloseListener
 
onClosed(Connection, Connection.CloseType) - Method in interface org.glassfish.grizzly.Connection.CloseListener
Deprecated.
 
onClosed() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
onClosed() - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
onClosed() - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
onCloseEvent(Connection) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when Connection gets closed.
onCloseEvent(Connection) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when Connection gets closed.
onCloseInputSource() - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamReader.Input
 
onCloseInputSource() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
onCloseInputSource() - Method in class org.glassfish.grizzly.streams.TransformerInput
 
onCommit() - Method in interface org.glassfish.grizzly.http.io.OutputBuffer.LifeCycleListener
 
onComplete(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChainContext.CompletionListener
The method is called, when passed FilterChainContext processing is complete.
onComplete() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
The method is called when this SafeFutureImpl is marked as completed.
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(Connection) - Method in interface org.glassfish.grizzly.ssl.SSLBaseFilter.HandshakeListener
 
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.
onConnect(TyrusWebSocket, UpgradeRequest, String, List<Extension>, String) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection is established.
onConnect(UpgradeRequest, String, List<Extension>, String) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when the opening handshake between both endpoints has been completed.
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).
onConnectFailure(Exception) - Method in class org.glassfish.tyrus.client.ClientManager.ReconnectHandler
Called when there is a connection failure.
onConnectionAcceptEvent(Connection) - Method in class org.glassfish.grizzly.http.KeepAliveProbe.Adapter
Method will be called, when new keep-alive HTTP connection is getting established.
onConnectionAcceptEvent(Connection) - Method in interface org.glassfish.grizzly.http.KeepAliveProbe
Method will be called, when new keep-alive HTTP connection is getting established.
onContentChunkParseEvent(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when HTTP message content chunk gets parsed (either request or response).
onContentChunkParseEvent(Connection, HttpContent) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when HTTP message content chunk gets parsed (either request or response).
onContentChunkSerializeEvent(Connection, HttpContent) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when HTTP message content chunk is prepared to be serialized (either request or response).
onContentChunkSerializeEvent(Connection, HttpContent) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when HTTP message content chunk is prepared to be serialized (either request or response).
onContentEncodingParseEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when ContentEncoding will be applied during the parsing/decoding of the certain HTTP message content chunk.
onContentEncodingParseEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when ContentEncoding will be applied during the parsing/decoding of the certain HTTP message content chunk.
onContentEncodingParseResultEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
This method will be called after the ContentEncoding has been applied.
onContentEncodingParseResultEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
This method will be called after the ContentEncoding has been applied.
onContentEncodingSerializeEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
/** Method will be called, when ContentEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
onContentEncodingSerializeEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
/** Method will be called, when ContentEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
onContentEncodingSerializeResultEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when ContentEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
onContentEncodingSerializeResultEvent(Connection, HttpHeader, Buffer, ContentEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when ContentEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
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.
onDataReceivedEvent(Connection, Buffer) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when Buffer will come for processing to the HttpCodecFilter (either request or response).
onDataReceivedEvent(Connection, Buffer) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when Buffer will come for processing to the HttpCodecFilter (either request or response).
onDataSentEvent(Connection, Buffer) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when Buffer, produced by the HttpCodecFilter will be ready to go to the next Filter in the chain and finally written on wire.
onDataSentEvent(Connection, Buffer) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when Buffer, produced by the HttpCodecFilter will be ready to go to the next Filter in the chain and finally written on wire.
onDisconnect(CloseReason) - Method in class org.glassfish.tyrus.client.ClientManager.ReconnectHandler
onEntryAddedEvent(FileCache, FileCacheEntry) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
Method will be called, when file cache entry gets added.
onEntryAddedEvent(FileCache, FileCacheEntry) - Method in interface org.glassfish.grizzly.http.server.filecache.FileCacheProbe
Method will be called, when file cache entry gets added.
onEntryHitEvent(FileCache, FileCacheEntry) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
Method will be called, when file cache entry gets hit.
onEntryHitEvent(FileCache, FileCacheEntry) - Method in interface org.glassfish.grizzly.http.server.filecache.FileCacheProbe
Method will be called, when file cache entry gets hit.
onEntryMissedEvent(FileCache, String, String) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
Method will be called, when file cache entry is missed for some resource.
onEntryMissedEvent(FileCache, String, String) - Method in interface org.glassfish.grizzly.http.server.filecache.FileCacheProbe
Method will be called, when file cache entry is missed for some resource.
onEntryRemovedEvent(FileCache, FileCacheEntry) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
Method will be called, when file cache entry gets removed.
onEntryRemovedEvent(FileCache, FileCacheEntry) - Method in interface org.glassfish.grizzly.http.server.filecache.FileCacheProbe
Method will be called, when file cache entry gets removed.
onError(Session, Throwable) - Method in class javax.websocket.Endpoint
Developers may implement this method when the web socket session creates some kind of error that is not modeled in the web socket protocol.
OnError - Annotation Type in javax.websocket
This method level annotation can be used to decorate a Java method that wishes to be called in order to handle errors.
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.
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(Throwable) - Method in interface org.glassfish.tyrus.client.TyrusClientEngine.ClientHandshakeListener
Called when an error is found in handshake response.
onError(Session, Throwable) - Method in class org.glassfish.tyrus.core.AnnotatedEndpoint
 
onError(TyrusWebSocket, Throwable) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
This method will be invoked if an unexpected exception is caught by the WebSocket runtime.
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(Connection, HttpPacket, Throwable) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when error occurs during the HttpCodecFilter processing.
onErrorEvent(Connection, HttpPacket, Throwable) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when error occurs during the HttpCodecFilter processing.
onErrorEvent(FileCache, Throwable) - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheProbe.Adapter
Method will be called, when error occurs on the FileCache.
onErrorEvent(FileCache, Throwable) - Method in interface org.glassfish.grizzly.http.server.filecache.FileCacheProbe
Method will be called, when error occurs on the FileCache.
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.
onExtensionNegotiation(ExtendedExtension.ExtensionContext, List<Extension.Parameter>) - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension
Parameter negotiation.
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
 
onFilterChainChanged(FilterChain) - Method in class org.glassfish.grizzly.utils.LogFilter
 
onFragment(BinaryFrame, boolean) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when a fragmented binary message has been received.
onFragment(TextFrame, boolean) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when a fragmented textual message has been received.
onHandshakeResponse(ExtendedExtension.ExtensionContext, List<Extension.Parameter>) - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension
Called only client side when handshake response arrives.
onHandShakeResponse(UpgradeRequest, UpgradeResponse) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Invoked when server side handshake is ready to send response.
onHeaderParseEvent(Connection, HttpHeader, int) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when HTTP message header gets parsed (either request or response).
onHeaderParseEvent(Connection, HttpHeader, int) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when HTTP message header gets parsed (either request or response).
onHeaderSerializeEvent(Connection, HttpHeader, Buffer) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when HTTP message header gets serialized (either request or response).
onHeaderSerializeEvent(Connection, HttpHeader, Buffer) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when HTTP message header gets serialized (either request or response).
onHitEvent(Connection, int) - Method in class org.glassfish.grizzly.http.KeepAliveProbe.Adapter
Method will be called, when HTTP request comes on a kept alive connection.
onHitEvent(Connection, int) - Method in interface org.glassfish.grizzly.http.KeepAliveProbe
Method will be called, when HTTP request comes on a kept alive connection.
onHttpContentEncoded(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpContentEncoded(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked when a HTTP body chunk has been encoded in preparation to being transmitted to the user-agent.
onHttpContentEncoded(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpContentError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpContentError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Callback which is invoked when parsing an HTTP message payload fails.
onHttpContentError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpContentParsed(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpContentParsed(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked as request/response body content has been processed by this Filter.
onHttpContentParsed(HttpContent, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpHeaderError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpHeaderError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Callback which is invoked when parsing an HTTP message header fails.
onHttpHeaderError(HttpHeader, FilterChainContext, Throwable) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpHeaderParsed(HttpHeader, Buffer, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpHeaderParsed(HttpHeader, Buffer, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Callback invoked when the HTTP message header parsing is complete.
onHttpHeaderParsed(HttpHeader, Buffer, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpHeadersEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpHeadersEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked when HTTP headers have been encoded in preparation to being transmitted to the user-agent.
onHttpHeadersEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpHeadersParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpHeadersParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked when all headers of the packet have been parsed.
onHttpHeadersParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onHttpPacketParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onHttpPacketParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Callback method, called when HttpPacket parsing has been completed.
onHttpPacketParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onInitialLineEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onInitialLineEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked when the intial response line has been encoded in preparation to being transmitted to the user-agent.
onInitialLineEncoded(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
onInitialLineParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpClientFilter
 
onInitialLineParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Invoked when either the request line or status line has been parsed.
onInitialLineParsed(HttpHeader, FilterChainContext) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
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.
onMessage(T, boolean) - Method in interface javax.websocket.MessageHandler.Partial
Called when the next part of a message has been fully received.
onMessage(T) - Method in interface javax.websocket.MessageHandler.Whole
Called when the message has been fully received.
OnMessage - Annotation Type in javax.websocket
This method level annotation can be used to make a Java method receive incoming web socket messages.
onMessage(TyrusWebSocket, ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming text message from the given remote endpoint.
onMessage(TyrusWebSocket, String) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming text message from the given remote endpoint.
onMessage(BinaryFrame) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when a binary message has been received.
onMessage(TextFrame) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when a text message has been received.
onMissingResource(Request, Response) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
The method will be called, if the static resource requested by the Request wasn't found, so StaticHttpHandler implementation may try to workaround this situation.
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.
onOpen(Session, EndpointConfig) - Method in class javax.websocket.Endpoint
Developers must implement this method to be notified when a new conversation has just begun.
OnOpen - Annotation Type in javax.websocket
This method level annotation can be used to decorate a Java method that wishes to be called when a new web socket session is open.
onOpen(Session, EndpointConfig) - Method in class org.glassfish.tyrus.core.AnnotatedEndpoint
 
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
 
onPartialMessage(TyrusWebSocket, String, boolean) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming partial text message from the given remote endpoint.
onPartialMessage(TyrusWebSocket, ByteBuffer, boolean) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming partial binary message from the given remote endpoint.
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.
onPing(TyrusWebSocket, ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming ping message from the given remote endpoint.
onPing(PingFrame) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when the remote end-point has sent a ping frame.
onPong(TyrusWebSocket, ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Called by the provider when the web socket connection has an incoming pong message from the given remote endpoint.
onPong(PongFrame) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
This callback will be invoked when the remote end-point has sent a pong frame.
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
 
onRefuseEvent(Connection) - Method in class org.glassfish.grizzly.http.KeepAliveProbe.Adapter
Method will be called, when the Connection could be used in the keep alive mode, but due to KeepAlive config limitations it will be closed.
onRefuseEvent(Connection) - Method in interface org.glassfish.grizzly.http.KeepAliveProbe
Method will be called, when the Connection could be used in the keep alive mode, but due to KeepAlive config limitations it will be closed.
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.utils.LogFilter
 
onRequestCancelEvent(HttpServerFilter, Connection, Request) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
 
onRequestCancelEvent(HttpServerFilter, Connection, Request) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when Request processing is cancelled after suspend.
onRequestCompleteEvent(HttpServerFilter, Connection, Response) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
Method will be called, when Request processing will be completed.
onRequestCompleteEvent(HttpServerFilter, Connection, Response) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when Request processing will be completed.
onRequestReceiveEvent(HttpServerFilter, Connection, Request) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
Method will be called, when new Request will come.
onRequestReceiveEvent(HttpServerFilter, Connection, Request) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when new Request will come.
onRequestResumeEvent(HttpServerFilter, Connection, Request) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
Method will be called, when Request processing is resumed.
onRequestResumeEvent(HttpServerFilter, Connection, Request) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when Request processing is resumed.
onRequestSuspendEvent(HttpServerFilter, Connection, Request) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
Method will be called, when Request processing is suspended.
onRequestSuspendEvent(HttpServerFilter, Connection, Request) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when Request processing is suspended.
onRequestTimeoutEvent(HttpServerFilter, Connection, Request) - Method in class org.glassfish.grizzly.http.server.HttpServerProbe.Adapter
Method will be called, when Request processing is timeout after suspend.
onRequestTimeoutEvent(HttpServerFilter, Connection, Request) - Method in interface org.glassfish.grizzly.http.server.HttpServerProbe
Method will be called, when Request processing is timeout after suspend.
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.
onResult(SendResult) - Method in interface javax.websocket.SendHandler
Called once the message has been transmitted.
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
 
onSendBinary(byte[]) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send binary message event.
onSendBinary(byte[], boolean) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send partial binary message event.
onSendPing(byte[]) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send ping frame event.
onSendPong(byte[]) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send pong frame event.
onSendText(String) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send text message event.
onSendText(String, boolean) - Method in class org.glassfish.tyrus.core.cluster.SessionEventListener
Invoked on send partial text message event.
onSessionClosed(String) - Method in interface org.glassfish.tyrus.core.cluster.SessionListener
Invoked when session is closed.
onSessionCreated(Session) - Method in interface org.glassfish.tyrus.client.TyrusClientEngine.ClientHandshakeListener
Invoked when handshake is completed and provided Session is open and ready to be returned from WebSocketContainer.connectToServer(Class, javax.websocket.ClientEndpointConfig, java.net.URI) (and alternatives) call.
onSessionOpened(String) - Method in interface org.glassfish.tyrus.core.cluster.SessionListener
Invoked when session is opened.
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.
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(Response) - Method in interface org.glassfish.grizzly.http.server.TimeoutHandler
Method is called, when suspended Response timeout expired.
onTimeout(Connection) - Method in interface org.glassfish.grizzly.utils.ActivityCheckFilter.TimeoutHandler
 
onTimeout(Connection) - Method in interface org.glassfish.grizzly.utils.IdleTimeoutFilter.TimeoutHandler
 
onTimeoutEvent(Connection) - Method in class org.glassfish.grizzly.http.KeepAliveProbe.Adapter
Method will be called, when the keep alive Connection idle timeout expired.
onTimeoutEvent(Connection) - Method in interface org.glassfish.grizzly.http.KeepAliveProbe
Method will be called, when the keep alive Connection idle timeout expired.
onTraceRequest(Request, Response) - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
onTransferEncodingParseEvent(Connection, HttpHeader, Buffer, TransferEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when TransferEncoding will be applied during the parsing/decoding of the certain HTTP message content chunk.
onTransferEncodingParseEvent(Connection, HttpHeader, Buffer, TransferEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when TransferEncoding will be applied during the parsing/decoding of the certain HTTP message content chunk.
onTransferEncodingSerializeEvent(Connection, HttpHeader, Buffer, TransferEncoding) - Method in class org.glassfish.grizzly.http.HttpProbe.Adapter
Method will be called, when TransferEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
onTransferEncodingSerializeEvent(Connection, HttpHeader, Buffer, TransferEncoding) - Method in interface org.glassfish.grizzly.http.HttpProbe
Method will be called, when TransferEncoding will be applied during the serialization/encoding of the certain HTTP message content chunk.
onWorkerExit(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by AbstractThreadPool.Worker, when it's completing AbstractThreadPool.Worker.run() method execution, which in most cases means, that ThreadPool's thread will be released.
onWorkerExit(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
onWorkerStarted(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
Method is called by AbstractThreadPool.Worker, when it's starting AbstractThreadPool.Worker.run() method execution, which means, that ThreadPool's thread is getting active and ready to process tasks.
onWrite(Buffer, long) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Method will be called, when some data was written on the connection
onWrite(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Method will be called, when some data was written on the connection
onWriteEvent(Connection, Buffer, long) - Method in class org.glassfish.grizzly.ConnectionProbe.Adapter
Method will be called, when the Connection has written data.
onWriteEvent(Connection, Buffer, long) - Method in interface org.glassfish.grizzly.ConnectionProbe
Method will be called, when the Connection has written data.
onWriteFailure(Connection, AsyncWriteQueueRecord, Throwable) - Static method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
onWritePossible() - Method in interface org.glassfish.grizzly.WriteHandler
This callback will be invoked when the requirements as dictated by writer are met.
opcode(byte) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set opcode.
OPEN_ROOT_PATH_PATTERN - Static variable in class org.glassfish.tyrus.core.uri.internal.PathPattern
Path pattern matching the any URI path.
openClientSocket(String, ClientEndpointConfig, Map<String, Object>, ClientEngine) - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientContainer
 
openClientSocket(String, ClientEndpointConfig, Map<String, Object>, ClientEngine) - Method in interface org.glassfish.tyrus.spi.ClientContainer
Open client socket - connect to endpoint specified with url parameter.
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
 
OPTIONS - Static variable in class org.glassfish.grizzly.http.Method
 
order() - Method in interface org.glassfish.grizzly.Buffer
Retrieves this buffer's byte order.
order(ByteOrder) - Method in interface org.glassfish.grizzly.Buffer
Modifies this buffer's byte order.
order() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
order() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
order - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
order() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
order(ByteOrder) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
org.glassfish.grizzly - package org.glassfish.grizzly
 
org.glassfish.grizzly.asyncqueue - package org.glassfish.grizzly.asyncqueue
 
org.glassfish.grizzly.attributes - package org.glassfish.grizzly.attributes
 
org.glassfish.grizzly.compression.lzma - package org.glassfish.grizzly.compression.lzma
 
org.glassfish.grizzly.compression.lzma.impl - package org.glassfish.grizzly.compression.lzma.impl
 
org.glassfish.grizzly.compression.lzma.impl.lz - package org.glassfish.grizzly.compression.lzma.impl.lz
 
org.glassfish.grizzly.compression.lzma.impl.rangecoder - package org.glassfish.grizzly.compression.lzma.impl.rangecoder
 
org.glassfish.grizzly.compression.zip - package org.glassfish.grizzly.compression.zip
 
org.glassfish.grizzly.filterchain - package org.glassfish.grizzly.filterchain
 
org.glassfish.grizzly.http - package org.glassfish.grizzly.http
 
org.glassfish.grizzly.http.io - package org.glassfish.grizzly.http.io
 
org.glassfish.grizzly.http.server - package org.glassfish.grizzly.http.server
 
org.glassfish.grizzly.http.server.filecache - package org.glassfish.grizzly.http.server.filecache
 
org.glassfish.grizzly.http.server.io - package org.glassfish.grizzly.http.server.io
 
org.glassfish.grizzly.http.server.jmxbase - package org.glassfish.grizzly.http.server.jmxbase
 
org.glassfish.grizzly.http.server.naming - package org.glassfish.grizzly.http.server.naming
 
org.glassfish.grizzly.http.server.util - package org.glassfish.grizzly.http.server.util
 
org.glassfish.grizzly.http.util - package org.glassfish.grizzly.http.util
 
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
 
org.glassfish.tyrus.client - package org.glassfish.tyrus.client
 
org.glassfish.tyrus.container.grizzly.client - package org.glassfish.tyrus.container.grizzly.client
 
org.glassfish.tyrus.core - package org.glassfish.tyrus.core
 
org.glassfish.tyrus.core.cluster - package org.glassfish.tyrus.core.cluster
 
org.glassfish.tyrus.core.coder - package org.glassfish.tyrus.core.coder
 
org.glassfish.tyrus.core.extension - package org.glassfish.tyrus.core.extension
 
org.glassfish.tyrus.core.frame - package org.glassfish.tyrus.core.frame
 
org.glassfish.tyrus.core.l10n - package org.glassfish.tyrus.core.l10n
Common internal localization utility classes.
org.glassfish.tyrus.core.uri - package org.glassfish.tyrus.core.uri
 
org.glassfish.tyrus.core.uri.internal - package org.glassfish.tyrus.core.uri.internal
Common classes that provide support for URI templates, encoding/decoding of URI components and multivalued collections.
org.glassfish.tyrus.spi - package org.glassfish.tyrus.spi
 
ORIGIN_HEADER - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
ORIGIN_NOT_VERIFIED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Origin not verified.
OsgiRegistry - Class in org.glassfish.tyrus.core
Taken from Jersey 2.
output - Variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
Output - Interface in org.glassfish.grizzly.streams
 
OutputBuffer - Class in org.glassfish.grizzly.http.io
Abstraction exposing both byte and character methods to write content to the HTTP messaging system in Grizzly.
OutputBuffer() - Constructor for class org.glassfish.grizzly.http.io.OutputBuffer
 
outputBuffer - Variable in class org.glassfish.grizzly.http.server.Response
The associated output buffer.
OutputBuffer.LifeCycleListener - Interface in org.glassfish.grizzly.http.io
 
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
 

P

Package - Static variable in class org.glassfish.grizzly.http.server.Constants
Package name.
packetLimit - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
Pair<K,L> - Class in org.glassfish.grizzly.utils
Key : Value pair implementation.
Pair() - Constructor for class org.glassfish.grizzly.utils.Pair
 
Pair(K, L) - Constructor for class org.glassfish.grizzly.utils.Pair
 
parameterMap - Variable in class org.glassfish.grizzly.http.server.Request
Hash map used in the getParametersMap method.
ParameterMap - Class in org.glassfish.grizzly.http.server.util
Extended implementation of LinkedHashMap that includes a locked property.
ParameterMap() - Constructor for class org.glassfish.grizzly.http.server.util.ParameterMap
Construct a new, empty map with the default initial capacity and load factor.
ParameterMap(int) - Constructor for class org.glassfish.grizzly.http.server.util.ParameterMap
Construct a new, empty map with the specified initial capacity and default load factor.
ParameterMap(int, float) - Constructor for class org.glassfish.grizzly.http.server.util.ParameterMap
Construct a new, empty map with the specified initial capacity and load factor.
ParameterMap(Map<String, String[]>) - Constructor for class org.glassfish.grizzly.http.server.util.ParameterMap
Construct a new map with the same mappings as the given map.
parameterMap(Map<String, String[]>) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set parameter map.
parameters - Variable in class org.glassfish.grizzly.http.server.Request
 
Parameters - Class in org.glassfish.grizzly.http.util
 
Parameters() - Constructor for class org.glassfish.grizzly.http.util.Parameters
 
paramsAsString() - Method in class org.glassfish.grizzly.http.util.Parameters
Debug purpose
parse(Buffer) - Method in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
parse(Buffer, int, int) - Method in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
parse(String) - Method in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
parse(Buffer) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ClientCookiesBuilder
 
parse(Buffer, int, int) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ClientCookiesBuilder
 
parse(String) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ClientCookiesBuilder
 
parse(Buffer) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ServerCookiesBuilder
 
parse(Buffer, int, int) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ServerCookiesBuilder
 
parse(String) - Method in class org.glassfish.grizzly.http.CookiesBuilder.ServerCookiesBuilder
 
parse(String, ParsePosition) - Method in class org.glassfish.grizzly.http.util.FastDateFormat
 
parse(char, CharBuffer) - Method in class org.glassfish.tyrus.core.StrictUtf8.Parser
Parses a UCS-4 character from the given source buffer, handling surrogates.
parse(char, char[], int, int) - Method in class org.glassfish.tyrus.core.StrictUtf8.Parser
Parses a UCS-4 character from the given source buffer, handling surrogates.
parseClientCookies(Cookies, Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Parses a cookie header after the initial "Cookie:" [WS][$]token[WS]=[WS](token|QV)[;|,] RFC 2965 JVK
parseClientCookies(Cookies, Buffer, int, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Parses a cookie header after the initial "Cookie:" [WS][$]token[WS]=[WS](token|QV)[;|,] RFC 2965 JVK
parseClientCookies(Cookies, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Parses a cookie header after the initial "Cookie:" [WS][$]token[WS]=[WS](token|QV)[;|,] RFC 2965 JVK
parseClientCookies(Cookies, byte[], int, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Parses a cookie header after the initial "Cookie:" [WS][$]token[WS]=[WS](token|QV)[;|,] RFC 2965 JVK
parseClientCookies(Cookies, String, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Parses a cookie header after the initial "Cookie:" [WS][$]token[WS]=[WS](token|QV)[;|,] RFC 2965 JVK
parseCookies() - Method in class org.glassfish.grizzly.http.server.Request
Parse cookies.
parseDate(String, DateFormat[]) - Static method in class org.glassfish.grizzly.http.util.FastHttpDateFormat
Try to parse the given date as a HTTP date.
parsedMethod - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
parsedProtocol - Variable in class org.glassfish.grizzly.http.HttpHeader
 
parseHeaderFromBuffer(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, Buffer) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderFromBytes(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, byte[], int) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderName(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, byte[], int) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderName(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, Buffer) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeadersFromBuffer(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, Buffer) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeadersFromBytes(HttpHeader, MimeHeaders, HttpCodecFilter.HeaderParsingState, byte[], int) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderValue(HttpHeader, HttpCodecFilter.HeaderParsingState, byte[], int) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderValue(HttpHeader, HttpCodecFilter.HeaderParsingState, Buffer) - Static method in class org.glassfish.grizzly.http.HttpCodecFilter
 
parseHeaderValue(String) - Static method in class org.glassfish.tyrus.core.Utils
Parse header value - splits multiple values (quoted, unquoted) separated by comma.
parseHost(DataChunk, DataChunk, HttpRequestPacket) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
parseInt(byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Parses an unsigned integer from the specified sub-array of bytes.
parseInt(char[], int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
parseInt(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Parses an unsigned int from the specified sub-array of bytes.
parseLocales() - Method in class org.glassfish.grizzly.http.server.Request
Parse request locales.
parseLocalesHeader(String) - Method in class org.glassfish.grizzly.http.server.Request
Parse accept-language header value.
parseLong(byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Parses an unsigned long from the specified sub-array of bytes.
parseLong(char[], int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
parseLong(String, int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
parseLong(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Parses an unsigned long from the specified sub-array of bytes.
parseLong(DataChunk) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
parseLong(DataChunk, int, int) - Static method in class org.glassfish.grizzly.http.util.Ascii
 
parsePacket(FilterChainContext, HttpHeader, Buffer) - Method in class org.glassfish.grizzly.http.ChunkedTransferEncoding
Parse HTTP packet payload, represented by Buffer using specific transfer encoding.
parsePacket(FilterChainContext, HttpHeader, Buffer) - Method in class org.glassfish.grizzly.http.FixedLengthTransferEncoding
Parse HTTP packet payload, represented by Buffer using specific transfer encoding.
parsePacket(FilterChainContext, HttpHeader, Buffer) - Method in interface org.glassfish.grizzly.http.TransferEncoding
Parse HTTP packet payload, represented by Buffer using specific transfer encoding.
parseRequestParameters() - Method in class org.glassfish.grizzly.http.server.Request
Parse request parameters.
parseServerCookies(Cookies, byte[], int, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
 
parseServerCookies(Cookies, Buffer, int, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
 
parseServerCookies(Cookies, String, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
 
parseSessionId() - Method in class org.glassfish.grizzly.http.server.Request
Parse session id in URL.
parseVersion(String) - Static method in class org.glassfish.grizzly.utils.JdkVersion
 
parseWithLengthPrefix(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
parseWithTerminatingSeq(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
parsingNumericValue - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
ParsingResult - Class in org.glassfish.grizzly.http
Class, which represents result of TransferEncoding or ContentEncoding parsing.
PARTIAL_BINARY_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Partial binary message received out of order.
PARTIAL_CONTENT_206 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
PARTIAL_MESSAGE_BUFFER_OVERFLOW() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Partial message could not be delivered due to buffer overflow.
PARTIAL_TEXT_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Partial text message received out of order.
PATCH - Static variable in class org.glassfish.grizzly.http.Method
 
path - Variable in class org.glassfish.grizzly.http.Cookie
 
path - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
path - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Wrapper
 
pathInfo - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
PathParam - Annotation Type in javax.websocket.server
This annotation may be used to annotate method parameters on server endpoints where a URI-template has been used in the path-mapping of the ServerEndpoint annotation.
PathPattern - Class in org.glassfish.tyrus.core.uri.internal
A path pattern that is a regular expression generated from a URI path template.
PathPattern(String) - Constructor for class org.glassfish.tyrus.core.uri.internal.PathPattern
Create a path pattern and post fix with PathPattern.RightHandPath.capturingZeroOrMoreSegments.
PathPattern(PathTemplate) - Constructor for class org.glassfish.tyrus.core.uri.internal.PathPattern
Create a path pattern and post fix with PathPattern.RightHandPath.capturingZeroOrMoreSegments.
PathPattern(String, PathPattern.RightHandPath) - Constructor for class org.glassfish.tyrus.core.uri.internal.PathPattern
Create a path pattern and post fix with a right hand path pattern.
PathPattern(PathTemplate, PathPattern.RightHandPath) - Constructor for class org.glassfish.tyrus.core.uri.internal.PathPattern
Create a path pattern and post fix with a right hand path pattern.
PathPattern.RightHandPath - Enum in org.glassfish.tyrus.core.uri.internal
The set of right hand path patterns that may be appended to a path pattern.
PathSegment - Interface in org.glassfish.tyrus.core.uri.internal
Represents a URI path segment and any associated matrix parameters.
PathTemplate - Class in org.glassfish.tyrus.core.uri.internal
A URI template for a URI path.
PathTemplate(String) - Constructor for class org.glassfish.tyrus.core.uri.internal.PathTemplate
Create a URI path template and encode (percent escape) any characters of the template that are not valid URI characters.
patternFilterChain - Variable in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
PatternWithGroups - Class in org.glassfish.tyrus.core.uri.internal
A pattern for matching a string against a regular expression and returning capturing group values for any capturing groups present in the expression.
PatternWithGroups() - Constructor for class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Construct an empty pattern.
PatternWithGroups(String) - Constructor for class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Construct a new pattern.
PatternWithGroups(String, int[]) - Constructor for class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Construct a new pattern.
PatternWithGroups(Pattern) - Constructor for class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Construct a new pattern.
PatternWithGroups(Pattern, int[]) - Constructor for class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
Construct a new pattern.
pause() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Pauses the listener.
pause() - Method in class org.glassfish.grizzly.nio.NIOTransport
Pause UDPNIOTransport, so I/O events coming on its UDPNIOConnections will not be processed.
pause() - Method in interface org.glassfish.grizzly.Transport
Pauses the transport
payloadData(byte[]) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set payload data.
payloadLength(long) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set payload length.
PAYMENT_REQUIRED_402 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
peek(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeHolder, the difference from Attribute.get(org.glassfish.grizzly.attributes.AttributeHolder) is that default value or NullaryFunction won't be invoked.
peek(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Get attribute value, stored on the AttributeStorage, the difference from Attribute.get(AttributeStorage) is that default value or NullaryFunction won't be invoked.
peek() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
PendingWriteQueueLimitExceededException - Exception in org.glassfish.grizzly
Thrown when an attempt is made to add a record that exceeds the configured maximum queue size.
PendingWriteQueueLimitExceededException() - Constructor for exception org.glassfish.grizzly.PendingWriteQueueLimitExceededException
 
PendingWriteQueueLimitExceededException(String) - Constructor for exception org.glassfish.grizzly.PendingWriteQueueLimitExceededException
 
phrase - Variable in class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
pickupContentType(Response, String) - Static method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
PingFrame - Class in org.glassfish.tyrus.core.frame
Ping frame representation.
PingFrame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.PingFrame
Constructor.
PingFrame(byte[]) - Constructor for class org.glassfish.tyrus.core.frame.PingFrame
Constructor.
poison - Static variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
poisonAll() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
poisonAll() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
poll() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Gets the current processing task and reserves its place.
poll() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
poll(long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
poll() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
poll() - Method in interface org.glassfish.grizzly.utils.ObjectPool
 
PongFrame - Class in org.glassfish.tyrus.core.frame
Pong frame representation.
PongFrame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.PongFrame
Constructor.
PongFrame(byte[]) - Constructor for class org.glassfish.tyrus.core.frame.PongFrame
Constructor.
PongMessage - Interface in javax.websocket
The PongMessage interface represents a web socket pong.
PoolableObject - Interface in org.glassfish.grizzly.utils
 
PooledMemoryManager - Class in org.glassfish.grizzly.memory
A MemoryManager implementation based on a series of shared memory pools.
PooledMemoryManager() - Constructor for class org.glassfish.grizzly.memory.PooledMemoryManager
Creates a new PooledMemoryManager using the following defaults: 4 KiB base buffer size 3 pools 2 growth factor, which means 1st pool will contain buffers of size 4KiB, the 2nd - 16KiB, the 3rd - 64KiB Number of pool slices based on Runtime.getRuntime().availableProcessors() The initial allocation will use 10% of the heap The percentage of buffers to be preallocated during MemoryManager initialization
PooledMemoryManager(boolean) - Constructor for class org.glassfish.grizzly.memory.PooledMemoryManager
Creates a new PooledMemoryManager using the specified parameters for configuration.
PooledMemoryManager(int, int, int, int, float, float, boolean) - Constructor for class org.glassfish.grizzly.memory.PooledMemoryManager
Creates a new PooledMemoryManager using the specified parameters for configuration.
poolName - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
pop() - Method in class org.glassfish.grizzly.http.util.Parameters
Discard the last child.
populateCertificateAttribute(Request) - Static method in class org.glassfish.grizzly.http.server.util.RequestUtils
 
populateSSLAttributes(Request) - Static method in class org.glassfish.grizzly.http.server.util.RequestUtils
 
PortRange - Class in org.glassfish.grizzly
Immutable class representing a port range.
PortRange(int, int) - Constructor for class org.glassfish.grizzly.PortRange
Creates a port range with the given bounds (both inclusive).
PortRange(int) - Constructor for class org.glassfish.grizzly.PortRange
Creates a port range containing a single port.
pos - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
position() - Method in interface org.glassfish.grizzly.Buffer
Returns this buffer's position.
position(int) - Method in interface org.glassfish.grizzly.Buffer
Sets this buffer's position.
position() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
position(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
position() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
position(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
position() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
position(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
posState - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
POST - Static variable in class org.glassfish.grizzly.http.Method
 
POST - Static variable in class org.glassfish.grizzly.http.server.Constants
POST.
postpone() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
postSelect(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
postSelect(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
preClose() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
preClose() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
PRECONDITION_FAILED_412 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
preConfigure(Connection) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Pre-configures Connection object before actual connecting phase will be started.
preferredSubprotocols(List<String>) - Method in class javax.websocket.ClientEndpointConfig.Builder
Set the preferred sub protocols for the configuration this builder will build.
preloadAllCharsets() - Static method in class org.glassfish.grizzly.utils.Charsets
Preloads all Charsets available to the JMV, which makes charset searching faster (at the cost of memory).
prepare() - Method in class org.glassfish.grizzly.http.util.ContentType
Prepare the ContentType for the serialization.
prepare() - Method in class org.glassfish.grizzly.http.util.HeaderValue
Prepare the HeaderValue for the serialization.
prepare() - Method in class org.glassfish.grizzly.utils.Pair
 
prepare() - Method in interface org.glassfish.grizzly.utils.PoolableObject
 
prepareCharacterEncoder() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
prepareDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
prepareDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
prepareForShutdown() - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Method, which might be optionally called to prepare the filter for shutdown.
prepareForShutdown() - Method in class org.glassfish.grizzly.http.HttpServerFilter
Method, which might be optionally called to prepare the filter for shutdown.
prepareForShutdown(CompletionHandler<HttpServerFilter>) - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
Method, which might be optionally called to prepare the filter for shutdown.
prepareRemainder(FilterChainContext, DefaultFilterChain.FiltersState, int, int) - Static method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Locates a message remainder in the FilterChain, associated with the Connection and prepares the Context for remainder processing.
prepareRequest() - Method in class org.glassfish.tyrus.core.Handshake
Client side only - Compose the UpgradeRequest and store it for further use.
prepareSerialize(FilterChainContext, HttpHeader, HttpContent) - Method in class org.glassfish.grizzly.http.ChunkedTransferEncoding
This method will be called by HttpCodecFilter to let TransferEncoding prepare itself for the content serialization.
prepareSerialize(FilterChainContext, HttpHeader, HttpContent) - Method in class org.glassfish.grizzly.http.FixedLengthTransferEncoding
 
prepareSerialize(FilterChainContext, HttpHeader, HttpContent) - Method in interface org.glassfish.grizzly.http.TransferEncoding
This method will be called by HttpCodecFilter to let TransferEncoding prepare itself for the content serialization.
prepend(Buffer) - Method in interface org.glassfish.grizzly.Buffer
Prepend data from header.position() to header.limit() to the current buffer.
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
prepend(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
preSelect(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
preSelect(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
prevByte - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
previousFilterIdx() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
PrimitiveDecoders<T> - Class in org.glassfish.tyrus.core.coder
Collection of decoders for all primitive types.
PrimitiveDecoders() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders
 
PrimitiveDecoders.BooleanDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.BooleanDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.BooleanDecoder
 
PrimitiveDecoders.ByteDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.ByteDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.ByteDecoder
 
PrimitiveDecoders.CharacterDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.CharacterDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.CharacterDecoder
 
PrimitiveDecoders.DoubleDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.DoubleDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.DoubleDecoder
 
PrimitiveDecoders.FloatDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.FloatDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.FloatDecoder
 
PrimitiveDecoders.IntegerDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.IntegerDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.IntegerDecoder
 
PrimitiveDecoders.LongDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.LongDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.LongDecoder
 
PrimitiveDecoders.ShortDecoder - Class in org.glassfish.tyrus.core.coder
 
PrimitiveDecoders.ShortDecoder() - Constructor for class org.glassfish.tyrus.core.coder.PrimitiveDecoders.ShortDecoder
 
priority - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
probe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
probes - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
process(Context) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
process(E) - Method in interface org.glassfish.grizzly.Processor
Method will be called by framework to process some event, which occurred on a connection
process(Context) - Method in class org.glassfish.grizzly.StandaloneProcessor
This method should never be called, because StandaloneProcessor.isInterested(IOEvent) returns false for any IOEvent.
process(Frame, TyrusWebSocket) - Method in class org.glassfish.tyrus.core.ProtocolHandler
TODO.
processAsync(Context) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueue
Callback method, which is called async.
processAsync(Context) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Callback method, which is called async.
processAsync(Context) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Callback method, which is called async.
processByte(byte, CompositeBuffer.Setter) - Method in interface org.glassfish.grizzly.memory.CompositeBuffer.BulkOperation
Method is responsible to examine/change one single Buffer's byte.
processIncoming(ExtendedExtension.ExtensionContext, Frame) - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension
Process incoming frame.
processingChars() - Method in class org.glassfish.grizzly.http.io.InputBuffer
This method should be called if the InputBuffer is being used in conjunction with a Reader implementation.
ProcessingState - Class in org.glassfish.grizzly.http
Maintains semantic state necessary to proper HTTP processing.
ProcessingState() - Constructor for class org.glassfish.grizzly.http.ProcessingState
 
processor - Variable in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
processor(Processor) - Method in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
processor - Variable in class org.glassfish.grizzly.AbstractBindingHandler
 
processor - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processor(Processor) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processor - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default Processor
processor - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
processor - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
Processor<E extends Context> - Interface in org.glassfish.grizzly
Processor implementations are responsible for processing I/O events, which occur on connection.
ProcessorExecutor - Class in org.glassfish.grizzly
 
ProcessorExecutor() - Constructor for class org.glassfish.grizzly.ProcessorExecutor
 
ProcessorResult - Class in org.glassfish.grizzly
The interface represents the result of Processor execution.
ProcessorResult.Status - Enum in org.glassfish.grizzly
Enumeration represents the status/code of ProcessorResult.
processorSelector - Variable in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
processorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractBindingHandler.Builder
 
processorSelector - Variable in class org.glassfish.grizzly.AbstractBindingHandler
 
processorSelector - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler.Builder
 
processorSelector - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default ProcessorSelector
processorSelector - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
processorSelector - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
ProcessorSelector - Interface in org.glassfish.grizzly
Implementations of the interface will be responsible to find correct Processor, which will process IOEvent, occurred on the Connection
processOutgoing(ExtendedExtension.ExtensionContext, Frame) - Method in interface org.glassfish.tyrus.core.extension.ExtendedExtension
Process outgoing frame.
processParameters(Buffer, int, int) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processParameters(Buffer, int, int, Charset) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processParameters(char[], int, int) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processParameters(DataChunk) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processParameters(DataChunk, Charset) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processParameters(String) - Method in class org.glassfish.grizzly.http.util.Parameters
 
processQueue(Queue<TaskProcessor.Task>, TaskProcessor.Condition) - Static method in class org.glassfish.tyrus.container.grizzly.client.TaskProcessor
Processes as much tasks from the queue as possible.
processResponse(UpgradeResponse, Writer, Connection.CloseListener) - Method in class org.glassfish.tyrus.client.TyrusClientEngine
 
processResponse(UpgradeResponse, Writer, Connection.CloseListener) - Method in interface org.glassfish.tyrus.spi.ClientEngine
Process handshake response.
protocol - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
protocol(Protocol) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set the HTTP message protocol version.
protocol(String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set the HTTP message protocol version.
Protocol - Enum in org.glassfish.grizzly.http
Predefined HTTP protocol versions
protocolC - Variable in class org.glassfish.grizzly.http.HttpHeader
 
ProtocolException - Exception in org.glassfish.tyrus.core
Represents issue with parsing or producing websocket frame.
ProtocolException(String) - Constructor for exception org.glassfish.tyrus.core.ProtocolException
 
ProtocolHandler - Class in org.glassfish.tyrus.core
Tyrus protocol handler.
protocolString - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
PROVIDER_CLASS_COULD_NOT_BE_LOADED(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
The class {0} implementing provider {1} could not be loaded: {2}
PROVIDER_COULD_NOT_BE_CREATED(Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
The class {0} implementing provider {1} could not be instantiated: {2}
PROVIDER_NOT_FOUND(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
The class {0} implementing the provider {1} is not found.
PROXY_AUTHENTICATION_REQUIRED_407 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
PROXY_JROUTE - Static variable in class org.glassfish.grizzly.http.server.Constants
 
PROXY_URI - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientSocket
Can be used as client-side user property to set proxy.
push() - Method in class org.glassfish.grizzly.http.util.Parameters
Create ( or reuse ) a child that will be used during a sub-request.
PushBackContext - Class in org.glassfish.grizzly.asyncqueue
Deprecated.
push back logic is deprecated.
PushBackContext(AsyncWriteQueueRecord) - Constructor for class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
 
PushBackHandler - Interface in org.glassfish.grizzly.asyncqueue
Deprecated.
push back logic is deprecated.
put(byte) - Method in interface org.glassfish.grizzly.Buffer
Relative put method  (optional operation).
put(int, byte) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method  (optional operation).
put(Buffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(Buffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(ByteBuffer) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(ByteBuffer, int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(byte[]) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put(byte[], int, int) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
PUT - Static variable in class org.glassfish.grizzly.http.Method
 
put(String, String[]) - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Associate the specified value with the specified key in this map.
put(MemoryManager, Buffer, byte[], DataChunk) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(MemoryManager, Buffer, byte[], String) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(MemoryManager, Buffer, byte[]) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(MemoryManager, Buffer, byte[], int, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(MemoryManager, Buffer, Buffer) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(MemoryManager, Buffer, byte) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
put(ByteBuffer, int, int, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(Buffer, int, int, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(byte[], int, int, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
 
put(byte) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put(byte) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put(byte) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(int, byte) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(Buffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(byte[]) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
put(ThreadCache.CachedTypeIndex, Object) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
 
put(Object) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
 
put(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
put(K, List<V>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
put8BitString(String) - Method in interface org.glassfish.grizzly.Buffer
Relative bulk put method  (optional operation).
put8BitString(String) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
put8BitString(String) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
put8BitString(String) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putAll(Map) - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Copy all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends List<V>>) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
putByte(byte) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
putChar(char) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a char value  (optional operation).
putChar(int, char) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a char value  (optional operation).
putChar(char) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putChar(char) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putChar(char) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putChar(int, char) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putDouble(double) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a double value  (optional operation).
putDouble(int, double) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a double value  (optional operation).
putDouble(double) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putDouble(double) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putDouble(double) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putDouble(int, double) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putFloat(float) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a float value  (optional operation).
putFloat(int, float) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a float value  (optional operation).
putFloat(float) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putFloat(float) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putFloat(float) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putFloat(int, float) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putInt(int) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing an int value  (optional operation).
putInt(int, int) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing an int value  (optional operation).
putInt(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putInt(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putInt(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putInt(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putLong(long) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a long value  (optional operation).
putLong(int, long) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a long value  (optional operation).
putLong(long) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putLong(long) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putLong(long) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putLong(int, long) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putShort(short) - Method in interface org.glassfish.grizzly.Buffer
Relative put method for writing a short value  (optional operation).
putShort(int, short) - Method in interface org.glassfish.grizzly.Buffer
Absolute put method for writing a short value  (optional operation).
putShort(short) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
putShort(short) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
putShort(short) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putShort(int, short) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
putSingle(K, V) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Set the value for the key to be a one item list consisting of the supplied value.
putSingle(K, V) - Method in interface org.glassfish.tyrus.core.uri.internal.MultivaluedMap
Set the key's value to be a one item list consisting of the supplied value.
putToArray(ByteBuffer) - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
putToCache(ThreadCache.CachedTypeIndex<E>, E) - Static method in class org.glassfish.grizzly.ThreadCache
 
putToCache(Thread, ThreadCache.CachedTypeIndex<E>, E) - Static method in class org.glassfish.grizzly.ThreadCache
 
putToCache(ThreadCache.CachedTypeIndex<E>, E) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 

Q

query(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Set the query portion of the request URI.
queryString - Variable in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
queryString(String) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set query string.
QUESTION - Static variable in class org.glassfish.grizzly.http.server.Constants
'?'.
QUESTION - Static variable in class org.glassfish.grizzly.http.util.Constants
'?'.
queue - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
queueAction(FilterChainContext) - Method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
 
queueLimit - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
queueRecord - Variable in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
 

R

RANDOM - Static variable in class org.glassfish.grizzly.AbstractBindingHandler
 
RangeDecoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
RangeDecoder
RangeDecoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
RangeEncoder - Class in org.glassfish.grizzly.compression.lzma.impl.rangecoder
RangeEncoder
RangeEncoder() - Constructor for class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
rawCookies - Variable in class org.glassfish.grizzly.http.server.Request
 
read(Connection<L>) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data.
read(Connection<L>, Buffer) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in class org.glassfish.grizzly.AbstractReader
Method reads data to the buffer.
read(Connection, CompletionHandler<ReadResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(FilterChainContext) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
read(FilterChainContext) - Method in interface org.glassfish.grizzly.filterchain.FilterChain
 
read() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Performs a blocking read.
read(byte[], int, int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
read(CharBuffer) - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
read(char[], int, int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
Method reads data to the buffer.
read() - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read(CompletionHandler<ReadResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
read(Connection<SocketAddress>, Buffer, CompletionHandler<ReadResult<Buffer, SocketAddress>>, Interceptor<ReadResult>, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
Method reads data to the message.
read(Connection, Buffer) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
read(UDPNIOConnection, Buffer) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
read(UDPNIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
read(Connection, CompletionHandler<ReadResult>) - Method in interface org.glassfish.grizzly.Processor
 
read() - Method in interface org.glassfish.grizzly.Readable
Method reads data.
read(CompletionHandler<ReadResult<M, L>>) - Method in interface org.glassfish.grizzly.Readable
 
read(Connection<L>) - Method in interface org.glassfish.grizzly.Reader
Method reads data.
read(Connection<L>, Buffer) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection<L>, Buffer, CompletionHandler<ReadResult<Buffer, L>>, Interceptor<ReadResult>) - Method in interface org.glassfish.grizzly.Reader
Method reads data to the buffer.
read(Connection, CompletionHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
read() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
read() - Method in interface org.glassfish.grizzly.streams.Input
 
read() - Method in class org.glassfish.grizzly.streams.StreamInput
 
read() - Method in class org.glassfish.grizzly.utils.BufferInputStream
read(byte[], int, int) - Method in class org.glassfish.grizzly.utils.BufferInputStream
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
read0(NIOConnection, ReadResult<Buffer, SocketAddress>, Buffer, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
read0(Connection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
READ_EVENT - Static variable in interface org.glassfish.grizzly.Reader
 
Readable<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to read data from internal source to a Buffer.
readBlock() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
readBoolean() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next boolean in the stream.
readBoolean() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next boolean in the stream.
readBooleanArray(boolean[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with booleans (byte 1=true, 0=false) from the stream.
readBooleanArray(boolean[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with booleans (byte 1=true, 0=false) from the stream.
readBuffer() - Method in interface org.glassfish.grizzly.http.io.BinaryNIOInputSource
Returns the underlying Buffer that backs this InputSource.
readBuffer(int) - Method in interface org.glassfish.grizzly.http.io.BinaryNIOInputSource
Returns the Buffer of a given size, which represents a chunk of the underlying Buffer that backs this InputSource.
readBuffer() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
readBuffer(int) - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
readBuffer(TCPNIOConnection, Buffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readBufferSize - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default buffer size for read operations
readBufferSize - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
readByte() - Method in class org.glassfish.grizzly.http.io.InputBuffer
This method always blocks.
readByte() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next byte in the stream.
readByte() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next byte in the stream.
readByteArray(byte[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with bytes from the stream.
readByteArray(byte[], int, int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with bytes from the stream.
readByteArray(byte[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with bytes from the stream.
readByteArray(byte[], int, int) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with bytes from the stream.
readBytes(Buffer) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill the buffer with data from the stream (that is, copy data from the stream to fill buffer from position to limit).
readBytes(Buffer) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill the buffer with data from the stream (that is, copy data from the stream to fill buffer from position to limit).
readChar() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
readChar() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next character in the stream.
readChar() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next character in the stream.
readCharArray(char[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readCharArray(char[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readCompositeBuffer(TCPNIOConnection, CompositeBuffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readDouble() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next double in the stream.
readDouble() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next double in the stream.
readDoubleArray(double[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readDoubleArray(double[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
Reader<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to read data from Connection to a Buffer.
ReaderDecoder - Class in org.glassfish.tyrus.core.coder
Built in Decoder for Reader.
ReaderDecoder() - Constructor for class org.glassfish.tyrus.core.coder.ReaderDecoder
 
readFloat() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next float in the stream.
readFloat() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next float in the stream.
readFloatArray(float[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readFloatArray(float[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readFromFileChannel(FileChannel, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Reads data from the FileChannel into the Buffer.
ReadHandler - Interface in org.glassfish.grizzly.http.server.io
Deprecated.
please use ReadHandler
ReadHandler - Interface in org.glassfish.grizzly
This class represents a call-back mechanism that will notify implementations as more input data becomes available to read without blocking.
ReadHandler - Interface in org.glassfish.tyrus.spi
Read handler provides a way for a transport to pass websocket connection data to tyrus runtime.
readInt() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next int in the stream.
readInt() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next int in the stream.
readIntArray(int[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readIntArray(int[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readLong() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next long in the stream.
readLong() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next long in the stream.
readLongArray(long[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readLongArray(long[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorReader
 
readNow0(NIOConnection, Buffer, ReadResult<Buffer, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorReader
 
readOnly - Variable in class org.glassfish.grizzly.memory.HeapBuffer
 
ReadResult<K,L> - Class in org.glassfish.grizzly
Result of read operation, returned by Readable.
ReadResult() - Constructor for class org.glassfish.grizzly.ReadResult
 
ReadResult(Connection<L>) - Constructor for class org.glassfish.grizzly.ReadResult
 
ReadResult(Connection<L>, K, L, int) - Constructor for class org.glassfish.grizzly.ReadResult
 
readShort() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Get the next short in the stream.
readShort() - Method in interface org.glassfish.grizzly.streams.StreamReader
Get the next short in the stream.
readShortArray(short[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
Fill data with characters from the stream.
readShortArray(short[]) - Method in interface org.glassfish.grizzly.streams.StreamReader
Fill data with characters from the stream.
readSimpleBuffer(TCPNIOConnection, Buffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
readTimeout - Variable in class org.glassfish.grizzly.AbstractTransport
 
readTimeout - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
readTimeoutMillis - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
ready() - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
ready() - Method in interface org.glassfish.grizzly.ShutdownContext
Invoked by called GracefulShutdownListener to notify the graceful termination process that it's safe to terminate the transport.
readyData() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Depending on the InputBuffer mode, method will return either number of available bytes or characters ready to be read without blocking.
readyData() - Method in interface org.glassfish.grizzly.InputSource
 
ReadyFutureImpl<R> - Class in org.glassfish.grizzly.impl
Future implementation with the specific unmodifiable result.
reallocate(ByteBufferWrapper, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Reallocate Buffer to a required size.
reallocate(HeapBuffer, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Reallocate Buffer to a required size.
reallocate(E, int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Reallocate Buffer to a required size.
reallocate(Buffer, int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Reallocates an existing buffer to at least the specified size.
reallocate(E, int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.nio.transport.DefaultStreamWriter.Output
 
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
reallocateBuffer(Buffer, int) - Method in class org.glassfish.grizzly.streams.TransformerOutput
 
reallocateByteBuffer(ByteBuffer, int) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
reallocateByteBuffer(ByteBuffer, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
reallocateByteBuffer(MemoryManager, ByteBuffer, int) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
reallocateHeapBuffer(HeapBuffer, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
realReadBytes(byte[], int, int) - Method in interface org.glassfish.grizzly.http.util.ByteChunk.ByteInputChannel
Read new bytes ( usually the internal conversion buffer ).
realReadChars(char[], int, int) - Method in interface org.glassfish.grizzly.http.util.CharChunk.CharInputChannel
Read new bytes ( usually the internal conversion buffer ).
realWriteBytes(byte[], int, int) - Method in interface org.glassfish.grizzly.http.util.ByteChunk.ByteOutputChannel
Send the bytes ( usually the internal conversion buffer ).
realWriteChars(char[], int, int) - Method in interface org.glassfish.grizzly.http.util.CharChunk.CharOutputChannel
Send the bytes ( usually the internal conversion buffer ).
reasonPhrase - Variable in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
reasonPhrase(String) - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
Sets the status reason phrase for this response.
reconfigure(ThreadPoolConfig) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
RECONNECT_HANDLER - Static variable in class org.glassfish.tyrus.client.ClientManager
Property usable in ClientManager.getProperties().
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
recycle() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
recycle() - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Recycle AttributeHolder
recycle() - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Recycle AttributeHolder
recycle() - Method in interface org.glassfish.grizzly.Cacheable
 
recycle() - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
recycle() - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
recycle() - Method in class org.glassfish.grizzly.Context
Recycle this Context
recycle(boolean) - Method in interface org.glassfish.grizzly.GrizzlyFuture
Recycle GrizzlyFuture now.
recycle() - Method in class org.glassfish.grizzly.http.Cookie
 
recycle() - Method in class org.glassfish.grizzly.http.Cookies
Recycle.
recycle() - Method in class org.glassfish.grizzly.http.HttpBrokenContent
recycle() - Method in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
recycle() - Method in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
recycle() - Method in class org.glassfish.grizzly.http.HttpContent
recycle() - Method in class org.glassfish.grizzly.http.HttpHeader
recycle() - Method in class org.glassfish.grizzly.http.HttpTrailer
recycle() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Recycle this InputBuffer for reuse.
recycle() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Recycle the output buffer.
recycle() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
recycle() - Method in class org.glassfish.grizzly.http.ParsingResult
 
recycle() - Method in class org.glassfish.grizzly.http.ProcessingState
Resets values to their initial states.
recycle() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
recycle() - Method in class org.glassfish.grizzly.http.server.filecache.LazyFileCacheKey
 
recycle() - Method in class org.glassfish.grizzly.http.server.io.ServerInputBuffer
 
recycle() - Method in class org.glassfish.grizzly.http.server.io.ServerOutputBuffer
 
recycle() - Method in class org.glassfish.grizzly.http.server.Request
Release all object references, and initialize instance variables, in preparation for reuse of this object.
recycle() - Method in class org.glassfish.grizzly.http.server.Response
Release all object references, and initialize instance variables, in preparation for reuse of this object.
recycle() - Method in class org.glassfish.grizzly.http.server.util.MappingData
 
recycle() - Method in class org.glassfish.grizzly.http.server.util.SimpleDateFormats
 
recycle() - Method in class org.glassfish.grizzly.http.util.B2CConverter
Reset the internal state, empty the buffers.
recycle() - Method in class org.glassfish.grizzly.http.util.B2CConverterBlocking
Reset the internal state, empty the buffers.
recycle() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
recycle() - Method in class org.glassfish.grizzly.http.util.ByteChunk
Resets the message buff to an uninitialized state.
recycle() - Method in class org.glassfish.grizzly.http.util.C2BConverter
Reset the internal state, empty the buffers.
recycle() - Method in class org.glassfish.grizzly.http.util.CacheableDataChunk
 
recycle() - Method in class org.glassfish.grizzly.http.util.CharChunk
Resets the message bytes to an uninitialized state.
recycle() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
recycle() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Resets the message bytes to an uninitialized (NULL) state.
recycle() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Clears all header fields.
recycle() - Method in class org.glassfish.grizzly.http.util.Parameters
 
recycle() - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
recycle() - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
recycle() - Method in class org.glassfish.grizzly.http.util.UTF8Decoder
 
recycle() - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
 
recycle(boolean) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycle() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.BufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
recycle() - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
recycle() - Method in class org.glassfish.grizzly.ReadResult
 
recycle() - Method in class org.glassfish.grizzly.TransformationResult
Recycle this Context
recycle() - Method in class org.glassfish.grizzly.WriteResult
 
recycleAndReset() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
recycleMark - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
recycleTemporaryArtifacts(Selector, SelectionKey) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
recycleTrack - Variable in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
redirectPath - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
redirectURLCC - Variable in class org.glassfish.grizzly.http.server.Response
Recyclable buffer to hold the redirect URL.
reduceLastAllocated(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
reduceOffsets(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
ReflectionHelper - Class in org.glassfish.tyrus.core
Utility methods for Java reflection.
ReflectionHelper() - Constructor for class org.glassfish.tyrus.core.ReflectionHelper
 
ReflectionHelper.ClassTypePair - Class in org.glassfish.tyrus.core
A tuple consisting of a class and type of the class.
ReflectionHelper.ClassTypePair(Class) - Constructor for class org.glassfish.tyrus.core.ReflectionHelper.ClassTypePair
 
ReflectionHelper.ClassTypePair(Class, Type) - Constructor for class org.glassfish.tyrus.core.ReflectionHelper.ClassTypePair
 
ReflectionHelper.DeclaringClassInterfacePair - Class in org.glassfish.tyrus.core
A tuple consisting of a concrete class, declaring class that declares a generic interface type.
ReflectionHelper.TypeClassPair - Class in org.glassfish.tyrus.core
 
ReflectionHelper.TypeClassPair(Type, Class) - Constructor for class org.glassfish.tyrus.core.ReflectionHelper.TypeClassPair
 
register(Object, Object) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object as child of the passed parent object.
register(Object, Object, String) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object as child of the passed parent object with the specific name.
register() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
register(Class<?>, String) - Method in class org.glassfish.tyrus.core.TyrusWebSocketEngine
 
register(ServerEndpointConfig, String) - Method in class org.glassfish.tyrus.core.TyrusWebSocketEngine
 
register(Class<?>, String) - Method in interface org.glassfish.tyrus.spi.WebSocketEngine
 
register(ServerEndpointConfig, String) - Method in interface org.glassfish.tyrus.spi.WebSocketEngine
 
registerAddOn(AddOn) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Registers AddOn on this NetworkListener.
registerAtRoot(Object) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object at the root.
registerAtRoot(Object, String) - Method in class org.glassfish.grizzly.jmxbase.GrizzlyJmxManager
Register Grizzly JMX Object at the root with the passed name.
registerBroadcastListener(String, BroadcastListener) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Register broadcast listener.
registerChannel(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannel(SelectorRunner, SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannel(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannel(SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registerChannel(SelectorRunner, SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelAsync(SelectableChannel) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectableChannel, int, Object) - Method in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
registerChannelAsync(SelectorRunner, SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerChannelAsync(SelectableChannel) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registerChannelAsync(SelectorRunner, SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
registerChannelCompletionHandler - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
RegisterChannelResult - Class in org.glassfish.grizzly.nio
 
RegisterChannelResult(SelectorRunner, SelectionKey, SelectableChannel) - Constructor for class org.glassfish.grizzly.nio.RegisterChannelResult
 
registerKeyInterest(SelectorRunner, SelectionKey, int) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
registerKeyInterest(SelectorRunner, SelectionKey, int) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
registerLifeCycleListener(OutputBuffer.LifeCycleListener) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
registerServiceChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in interface org.glassfish.grizzly.nio.NIOChannelDistributor
 
registerServiceChannelAsync(SelectableChannel, int, Object, CompletionHandler<RegisterChannelResult>) - Method in class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
registerSessionListener(String, SessionListener) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Register session listener.
registrationStackTrace - Variable in class org.glassfish.grizzly.streams.BufferedInput
 
release(AttributeStorage) - Method in class org.glassfish.grizzly.AbstractTransformer
 
release() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Perform message specific actions to release resources held by the entity backing this WritableMessage.
release() - Method in class org.glassfish.grizzly.FileTransfer
Perform message specific actions to release resources held by the entity backing this WritableMessage.
release() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
release(ByteBufferWrapper) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Lets JVM Garbage collector to release buffer.
release() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
release() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
release(HeapBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Release Buffer.
release(E) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Release Buffer.
release(Buffer) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Release Buffer.
release(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
release() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
release(AttributeStorage) - Method in interface org.glassfish.grizzly.Transformer
The Transformer has done its work and can release all associated resource.
release() - Method in class org.glassfish.grizzly.utils.Pair
 
release() - Method in interface org.glassfish.grizzly.utils.PoolableObject
 
release(AttributeStorage) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.OutWindow
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeDecoder
 
releaseBuffer() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
releaseByteBuffer(ByteBuffer) - Method in interface org.glassfish.grizzly.memory.ByteBufferAware
 
releaseByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
 
releaseByteBuffer(MemoryManager, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.MemoryUtils
 
releaseHeapBuffer(HeapBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
 
releaseSpace(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Releases memory space in the queue.
releaseSpaceAndNotify(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Releases memory space in the queue and notifies registered QueueMonitors about the update.
remaining() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
remaining() - Method in interface org.glassfish.grizzly.asyncqueue.WritableMessage
Return the number of bytes remaining to be written.
remaining() - Method in interface org.glassfish.grizzly.Buffer
Returns the number of elements between the current position and the limit.
remaining() - Method in class org.glassfish.grizzly.FileTransfer
Return the number of bytes remaining to be written.
remaining() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
remaining() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
remaining() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
remaining() - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
remainingCapacity() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Always returns Integer.MAX_VALUE because a LinkedTransferQueue is not capacity constrained.
remoteAddr() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
remoteAddressC - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
RemoteEndpoint - Interface in javax.websocket
The RemoteEndpoint object is supplied by the container and represents the 'other end' or peer of the Web Socket conversation.
RemoteEndpoint.Async - Interface in javax.websocket
This representation of the peer of a web socket conversation has the ability to send messages asynchronously.
RemoteEndpoint.Basic - Interface in javax.websocket
This representation of the peer of a web socket conversation has the ability to send messages synchronously.
remoteHost() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
remoteHostC - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
REMOTELY_CLOSED_REASON - Static variable in class org.glassfish.grizzly.CloseReason
 
remotePort - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
remoteUser() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the name of the remote user that has been authenticated for this Request.
remove(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Remove the task from queue.
remove(AttributeHolder) - Method in class org.glassfish.grizzly.attributes.Attribute
Remove attribute value, stored on the AttributeHolder.
remove(AttributeStorage) - Method in class org.glassfish.grizzly.attributes.Attribute
Remove attribute value, stored on the AttributeStorage.
remove(Object) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
remove(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
remove(Object) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(int) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
remove(FileCacheEntry) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
remove(String) - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Remove the mapping for this key from the map if present.
remove(Object) - Method in class org.glassfish.grizzly.utils.ArraySet
remove(T[], Object) - Static method in class org.glassfish.grizzly.utils.ArrayUtils
Removes the element from the array.
remove(E) - Method in class org.glassfish.grizzly.utils.DelayedExecutor.DelayQueue
 
remove(Object) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Removes a single instance of the specified element from this queue, if it is present.
remove(Object) - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
removeAfterServiceListener(AfterServiceListener) - Method in class org.glassfish.grizzly.http.server.Request
Remove the "after-service" listener, which was previously added by Request.addAfterServiceListener(org.glassfish.grizzly.http.server.AfterServiceListener).
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
removeAll() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
removeAll() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Removes underlying Buffers, without disposing
removeAll(Object...) - Method in class org.glassfish.grizzly.utils.ArraySet
Remove element(s) from the set.
removeAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
removeAllHttpHandlers() - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
 
removeAllLifeCycleListener() - Method in class org.glassfish.grizzly.Context
 
removeAttribute(String) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Remove a name/value object.
removeAttribute(String) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Remove a name/value object.
removeAttribute(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Remove the specified request attribute if it exists.
removeAttribute(String) - Method in class org.glassfish.grizzly.http.server.Request
Remove the specified request attribute if it exists.
removeAttribute(String) - Method in class org.glassfish.grizzly.http.server.Session
Remove an attribute.
removeCharset(byte[]) - Static method in class org.glassfish.grizzly.http.util.ContentType
Removes the charset attribute from the content-type represented by an array.
removeCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Closeable
Remove the CloseListener.
removeCloseListener(CloseListener) - Method in interface org.glassfish.grizzly.Connection
removeCloseListener(Connection.CloseListener) - Method in interface org.glassfish.grizzly.Connection
removeCloseListener(CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
removeCloseListener(Connection.CloseListener) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
removeCompletionListener(FilterChainContext.CompletionListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
removeContentEncoding(ContentEncoding) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Removes the specified ContentEncoding from the HttpCodecFilter.
removeContext(String, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Remove a context from an existing host.
removeCopyListener(FilterChainContext.CopyListener) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
removeDocRoot(String) - Method in class org.glassfish.grizzly.http.server.CLStaticHttpHandler
Removes docRoot from the doc root list.
removeDocRoot(File) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandler
Removes the directory from the list of directories where static files will be serviced from.
removeHandshakeListener(SSLBaseFilter.HandshakeListener) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
removeHeader(String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Remove the specified header from this builder.
removeHeader(Header) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Remove the specified header from this builder.
removeHeader(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Removes a header field with the specified name.
removeHeader(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
removeHeader(String, String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Removes the headers with the given name whose values contain the given string.
removeHeaderMatches(String, String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Removes the headers with the given name whose values contain the given string.
removeHeaderMatches(Header, String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Removes the headers with the given name whose values contain the given string.
removeHost(String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Remove a host from the mapper.
removeHttpHandler(HttpHandler) - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
Remove a HttpHandler
removeHttpHandler(HttpHandler) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Removes the specified HttpHandler.
removeJmxEventListener(JmxEventListener) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Removes the specified JmxEventListener.
removeLifeCycleListener(IOEventLifeCycleListener) - Method in class org.glassfish.grizzly.Context
 
removeLifeCycleListener(OutputBuffer.LifeCycleListener) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
removeListener(String) - Method in class org.glassfish.grizzly.http.server.HttpServer
Removes the NetworkListener associated with the specified name.
removeMessageHandler(MessageHandler) - Method in interface javax.websocket.Session
Remove the given MessageHandler from the set belonging to this session.
removeMessageHandler(MessageHandler) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Not supported (yet?).
removeMessageHandler(MessageHandler) - Method in class org.glassfish.tyrus.core.TyrusSession
 
removeMonitoringProbe(ConnectionProbe) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Remove the ConnectionProbe.
removeNote(Note<E>) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Remove the Note value associated with this request.
removeNote(Note<E>) - Method in class org.glassfish.grizzly.http.server.Request
Remove the Note value associated with this request.
removeProbes(E...) - Method in class org.glassfish.grizzly.monitoring.DefaultMonitoringConfig
Remove the monitoring probes.
removeProbes(E...) - Method in interface org.glassfish.grizzly.monitoring.MonitoringConfig
Remove the monitoring probes.
removeRightBuffers(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
removeSession(String, String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Remove session from this Cluster context.
removeSession(Session) - Method in class org.glassfish.tyrus.core.ComponentProviderService
Remove Session from cache.
removeSessionCookies() - Method in class org.glassfish.grizzly.http.server.Response
Removes any Set-Cookie response headers whose value contains the string "JSESSIONID=" or "JSESSIONIDSSO="
removeTimeout(E) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
removeTransferEncoding(TransferEncoding) - Method in class org.glassfish.grizzly.http.HttpCodecFilter
Removes the specified TransferEncoding from the HttpCodecFilter.
removeWrapper(String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Remove a wrapper from the context associated with this wrapper.
removeWrapper(String, String, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Remove a wrapper from an existing context.
removeWrapper(Mapper.Context, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
 
renegotiate(SSLConnectionContext, FilterChainContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
Performs an SSL renegotiation.
rep0 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep1 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep2 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
rep3 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
replace(Buffer, Buffer) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
replace(Buffer, Buffer) - Method in class org.glassfish.grizzly.memory.CompositeBuffer
Replace one internal Buffer with another one.
replayPayload(Buffer) - Method in class org.glassfish.grizzly.http.io.InputBuffer
 
replayPayload(Buffer) - Method in class org.glassfish.grizzly.http.server.Request
Replays request's payload by setting new payload Buffer.
Request - Class in org.glassfish.grizzly.http.server
Wrapper object for the Coyote request.
Request(Response) - Constructor for class org.glassfish.grizzly.http.server.Request
 
request - Variable in class org.glassfish.grizzly.http.server.Request
HTTP Request Packet
request - Variable in class org.glassfish.grizzly.http.server.Response
The request with which this response is associated.
Request.PathResolver - Interface in org.glassfish.grizzly.http.server
 
REQUEST_ENTITY_TOO_LARGE_413 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
REQUEST_RANGE_NOT_SATISFIABLE_416 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
REQUEST_TIMEOUT_408 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
REQUEST_URI_TOO_LONG_414 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
RequestContext - Class in org.glassfish.tyrus.core
Implementation of all possible request interfaces.
RequestContext.Builder - Class in org.glassfish.tyrus.core
RequestContext.Builder() - Constructor for class org.glassfish.tyrus.core.RequestContext.Builder
 
RequestContext.Builder.IsUserInRoleDelegate - Interface in org.glassfish.tyrus.core
Is user in role delegate.
requestDispatcherPath - Variable in class org.glassfish.grizzly.http.server.Request
The current request dispatcher path.
requestedSessionCookie - Variable in class org.glassfish.grizzly.http.server.Request
Was the requested session ID received in a cookie?
requestedSessionId - Variable in class org.glassfish.grizzly.http.server.Request
The requested session ID (if any) for this request.
requestedSessionURL - Variable in class org.glassfish.grizzly.http.server.Request
Was the requested session ID received in a URL?
RequestExecutorProvider - Interface in org.glassfish.grizzly.http.server
An implementation of this interface will be responsible for executing user's code in HttpHandler.service(org.glassfish.grizzly.http.server.Request, org.glassfish.grizzly.http.server.Response) and notifying ReadHandler, WriteHandler registered by the user.
RequestExecutorProvider.SameThreadProvider - Class in org.glassfish.grizzly.http.server
The RequestExecutorProvider implementation, which always returns null to force the user code to be executed on the current Thread.
RequestExecutorProvider.SameThreadProvider() - Constructor for class org.glassfish.grizzly.http.server.RequestExecutorProvider.SameThreadProvider
 
RequestExecutorProvider.WorkerThreadProvider - Class in org.glassfish.grizzly.http.server
The RequestExecutorProvider implementation, which checks if the current Thread is a service Thread (see Threads.isService()).
RequestExecutorProvider.WorkerThreadProvider() - Constructor for class org.glassfish.grizzly.http.server.RequestExecutorProvider.WorkerThreadProvider
 
requestPacket - Variable in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
requestPacket(HttpRequestPacket) - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
requestParametersParsed - Variable in class org.glassfish.grizzly.http.server.Request
Request parameters parsed flag.
requestPath - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
requestURI - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
requestURI(URI) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set request URI.
RequestURIRef - Class in org.glassfish.grizzly.http.util
Request URI holder.
RequestURIRef() - Constructor for class org.glassfish.grizzly.http.util.RequestURIRef
 
RequestUtils - Class in org.glassfish.grizzly.http.server.util
 
RequestUtils() - Constructor for class org.glassfish.grizzly.http.server.util.RequestUtils
 
requiresAcknowledgement(boolean) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Allows consumers of this request to be notified if the user-agent requires acknowledgment of an expectation (i.e., the Expect header).
requiresAcknowledgement() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
requiresAcknowledgement() - Method in class org.glassfish.grizzly.http.server.Request
 
RerunFilterAction - Class in org.glassfish.grizzly.filterchain
This NextAction instructs the FilterChain to rerun the same Filter again.
reserveSpace(int) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Reserves memory space in the queue.
reset() - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
reset() - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
reset() - Method in interface org.glassfish.grizzly.Buffer
Resets this buffer's position to the previously-marked position.
reset() - Method in class org.glassfish.grizzly.Context
If implementation uses ObjectPool to store and reuse Context instances - this method will be called before Context will be offered to pool.
reset() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Release the context associated resources.
reset() - Method in class org.glassfish.grizzly.http.HttpBrokenContent
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.HttpContent.Builder
 
reset() - Method in class org.glassfish.grizzly.http.HttpContent
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
 
reset() - Method in class org.glassfish.grizzly.http.HttpHeader
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
reset() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
reset() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.HttpTrailer
Reset the internal state.
reset() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Only supported with binary data.
reset() - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Reset current response.
reset() - Method in class org.glassfish.grizzly.http.server.Response
Clears any data that exists in the buffer as well as the status code and headers.
reset(int, String) - Method in class org.glassfish.grizzly.http.server.Response
Reset this response, and specify the values for the HTTP status code and corresponding message.
reset() - Method in class org.glassfish.grizzly.http.server.SuspendStatus
 
reset() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Reset the current state of the parser to the beginning of the current string being parsed.
reset() - Method in class org.glassfish.grizzly.http.util.B2CConverter
 
reset() - Method in class org.glassfish.grizzly.http.util.B2CConverterBlocking
 
reset() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
reset() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
reset() - Method in class org.glassfish.grizzly.http.util.CacheableDataChunk
 
reset() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
reset() - Method in class org.glassfish.grizzly.http.util.ContentType
Resets the ContentType state.
reset() - Method in class org.glassfish.grizzly.http.util.ContentType.SettableContentType
 
reset() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
reset() - Static method in class org.glassfish.grizzly.http.util.StringCache
 
reset() - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
RESET - Static variable in interface org.glassfish.grizzly.Interceptor
 
reset() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
reset() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
reset() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
reset() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
reset(E) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
reset() - Method in class org.glassfish.grizzly.ReadResult
 
reset() - Method in class org.glassfish.grizzly.TransformationResult
If implementation uses ObjectPool to store and reuse TransformationResult instances - this method will be called before TransformationResult will be offered to pool.
reset() - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
reset() - Method in class org.glassfish.grizzly.WriteResult
 
RESET_CONTENT_205 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
resetBuffer() - Method in class org.glassfish.grizzly.http.server.Response
Reset the data buffer but not any status or header information.
resetBuffer(boolean) - Method in class org.glassfish.grizzly.http.server.Response
Reset the data buffer and the using Writer/Stream flags but not any status or header information.
resetBuffer() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
resetByteChunk() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
resetCharChunk() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
resetProperties() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
resetString() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
resetStringCache() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
resetStringCache() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
resetStringCache() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
resetStringValue() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Remove the cached string value.
resizeBuffer(MemoryManager, Buffer, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
resolve(Request) - Method in interface org.glassfish.grizzly.http.server.Request.PathResolver
 
resolveTemplateValues(UriComponent.Type, String, boolean, Map<String, ?>) - Static method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
Resolves template variables in the given template from _mapValues.
resolveTypeVariable(Class, Class, TypeVariable) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Given a type variable resolve the Java class of that variable.
resources - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
RESOURCES_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The JNDI directory context which is associated with the context.
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.BinaryFrame
 
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.CloseFrame
 
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.PingFrame
 
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.PongFrame
 
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.TextFrame
 
respond(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.frame.TyrusFrame
Execution part of frame processing.
response - Variable in class org.glassfish.grizzly.http.server.Request
The response with which this request is associated.
Response - Class in org.glassfish.grizzly.http.server
Wrapper object for the Coyote response.
Response() - Constructor for class org.glassfish.grizzly.http.server.Response
 
response - Variable in class org.glassfish.grizzly.http.server.Response
Coyote response.
Response.SuspendedContextImpl - Class in org.glassfish.grizzly.http.server
 
Response.SuspendedContextImpl() - Constructor for class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
Response.SuspendTimeout - Class in org.glassfish.grizzly.http.server
 
RESPONSE_CODE_MESSAGE - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
RESPONSE_COMPLETE_EVENT - Static variable in class org.glassfish.grizzly.http.HttpServerFilter
 
restore() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
result(R) - Method in interface org.glassfish.grizzly.impl.FutureImpl
Set the result value and notify about operation completion.
result - Variable in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
result(R) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
 
result(R) - Method in class org.glassfish.grizzly.impl.SafeFutureImpl
Set the result value and notify about operation completion.
result - Variable in class org.glassfish.grizzly.impl.UnsafeFutureImpl
 
result(R) - Method in class org.glassfish.grizzly.impl.UnsafeFutureImpl
Set the result value and notify about operation completion.
Result - Interface in org.glassfish.grizzly
Common I/O result interface.
ResultAware<E> - Interface in org.glassfish.grizzly.utils
 
resume() - Method in class org.glassfish.grizzly.Context
Notify Context its processing will be resumed in the current thread.
resume() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume processing of the current task
resume(NextAction) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume the current FilterChain task processing by completing the current Filter (the Filter, which suspended the processing) with the passed NextAction.
resume() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Resumes a paused listener.
resume() - Method in class org.glassfish.grizzly.http.server.Response
Complete the Response and finish/commit it.
resume() - Method in class org.glassfish.grizzly.nio.NIOTransport
Resume UDPNIOTransport, which has been paused before using NIOTransport.pause().
resume(Context) - Static method in class org.glassfish.grizzly.ProcessorExecutor
 
resume() - Method in interface org.glassfish.grizzly.Transport
Resumes the transport after a pause
resumeNext() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Resume processing of the current task starting from the Filter, which follows the Filter, which suspend the processing.
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.ChainProcessorSelector
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
retainAll(Collection<?>) - Method in class org.glassfish.grizzly.utils.ArraySet
retrieve(Properties) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
retryNow() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Instructs Grizzly to try to resend the message right now.
retryWhenPossible() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Instructs Grizzly to send this message once some resources get released.
reuseAddress - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
reverseDecode(LZMADecoder.LZMAInputState, RangeDecoder) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseDecode(LZMADecoder.LZMAInputState, short[], int, RangeDecoder, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeDecoder
 
reverseEncode(RangeEncoder, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseEncode(short[], int, RangeEncoder, int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseGetPrice(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
reverseGetPrice(short[], int, int, int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.BitTreeEncoder
 
rewind() - Method in interface org.glassfish.grizzly.Buffer
Rewinds this buffer.
rewind() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
rewind() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
rewind() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
rfc6265Enabled - Variable in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
RFC_6265_SUPPORT_ENABLED - Static variable in class org.glassfish.grizzly.http.util.CookieUtils
 
RoundRobinConnectionDistributor - Class in org.glassfish.grizzly.nio
RoundRobin NIOConnectionDistributor implementation, which allocates one SelectorRunner for OP_ACCEPT events and other event will be assign to a next SelectorRunner from the array.
RoundRobinConnectionDistributor(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
RoundRobinConnectionDistributor(NIOTransport, boolean) - Constructor for class org.glassfish.grizzly.nio.RoundRobinConnectionDistributor
 
rsv1(boolean) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set RSV1 flag.
rsv2(boolean) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set RSV2 flag.
rsv3(boolean) - Method in class org.glassfish.tyrus.core.frame.Frame.Builder
Set RSV3 flag.
RSV_INCORRECTLY_SET() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
RSV bit(s) incorrectly set.
run() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.DeregisterChannelOperation
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterChannelOperation
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RegisterKeyTask
 
run(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler.RunnableTask
 
run() - Method in interface org.glassfish.grizzly.nio.SelectorHandler.Task
 
run(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandlerTask
 
run() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
run() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
running - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 

S

SafeFutureImpl<R> - Class in org.glassfish.grizzly.impl
Safe FutureImpl implementation.
SafeFutureImpl() - Constructor for class org.glassfish.grizzly.impl.SafeFutureImpl
Creates SafeFutureImpl
SameThreadIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in a current thread.
saveLastResult(AttributeStorage, TransformationResult<K, L>) - Method in class org.glassfish.grizzly.AbstractTransformer
 
SEC_KEY_INVALID_LENGTH(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Invalid Sec-WebSocket-Key length.
SEC_KEY_INVALID_SERVER() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Sec-WebSocket-Key returned from server does not match expected response.
SEC_KEY_NULL_NOT_ALLOWED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Null Sec-WebSocket-Key is not allowed.
SEC_WEBSOCKET_ACCEPT - Static variable in interface javax.websocket.HandshakeResponse
The Sec-WebSocket-Accept header name.
SEC_WEBSOCKET_EXTENSIONS - Static variable in interface javax.websocket.server.HandshakeRequest
The Sec-WebSocket-Extensions header name
SEC_WEBSOCKET_KEY - Static variable in interface javax.websocket.server.HandshakeRequest
The Sec-WebSocket-Key header name
SEC_WEBSOCKET_PROTOCOL - Static variable in interface javax.websocket.server.HandshakeRequest
The Sec-WebSocket-Protocol header name
SEC_WEBSOCKET_VERSION - Static variable in interface javax.websocket.server.HandshakeRequest
The Sec-WebSocket-Version header name
SEC_WS_ORIGIN_HEADER - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
secure - Variable in class org.glassfish.grizzly.http.Cookie
 
secure - Variable in class org.glassfish.grizzly.http.HttpHeader
 
secure - Variable in class org.glassfish.grizzly.http.server.Request
Secure flag.
secure(boolean) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
Set secure state.
SEE_OTHER_303 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.ChainProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.DefaultProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.filterchain.FilterChainProcessorSelector
Returns FilterChain instance, if it's interested in processing passed IOEvent, or null otherwise.
select(SelectorRunner) - Method in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
select(SelectorRunner) - Method in interface org.glassfish.grizzly.nio.SelectorHandler
 
select(IOEvent, Connection) - Method in interface org.glassfish.grizzly.ProcessorSelector
Selects Processor, which will process connection event.
select(IOEvent, Connection) - Method in class org.glassfish.grizzly.StandaloneProcessorSelector
Always return null, which means no Processor was found to process IOEvent.
selectionKey - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
selectionKeyHandler - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
SelectionKeyHandler - Interface in org.glassfish.grizzly.nio
SelectionKeyHandler implementations are responsible for handling SelectionKey life cycle events.
selectionKeyHandler - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
selectionKeyInterest2IoEvent(int) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
selectionKeyInterest2IoEvent(int) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
SELECTOR_THREAD_POOL_CONFIG - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientSocket
Client-side property to set custom selector ThreadPoolConfig.
selectorHandler - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
SelectorHandler - Interface in org.glassfish.grizzly.nio
 
selectorHandler - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
SelectorHandler.Task - Interface in org.glassfish.grizzly.nio
 
SelectorHandlerTask - Interface in org.glassfish.grizzly.nio
Task, which may be registered on SelectorHandler and executed in a Selector thread.
selectorPool - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
selectorProvider - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
selectorProvider - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
selectorRunner - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
SelectorRunner - Class in org.glassfish.grizzly.nio
Class is responsible for processing certain (single) SelectorHandler
selectorRunnerCount - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
selectorRunners - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
Selectors - Class in org.glassfish.grizzly.nio
Utility class for Selector related operations.
Selectors() - Constructor for class org.glassfish.grizzly.nio.Selectors
 
selectTimeout - Variable in class org.glassfish.grizzly.nio.DefaultSelectorHandler
 
SEMI_COLON - Static variable in class org.glassfish.grizzly.http.util.Constants
SEMI_COLON.
send(Frame, boolean) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
send(Frame) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
send(byte[]) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
send(byte[], SendHandler) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
send(String) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
send(String, SendHandler) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
SEND_FILE_ATTR - Static variable in class org.glassfish.grizzly.http.server.Request
The value of this request attribute, as set by the developer must be a File that exists, is not a directory, and is readable.
SEND_FILE_ENABLED_ATTR - Static variable in class org.glassfish.grizzly.http.server.Request
Request attribute will be associated with a boolean value indicating whether or not it's possible to transfer a File using sendfile.
SEND_FILE_START_OFFSET_ATTR - Static variable in class org.glassfish.grizzly.http.server.Request
The value of this request attribute signifies the starting offset of the file transfer.
SEND_FILE_WRITE_LEN_ATTR - Static variable in class org.glassfish.grizzly.http.server.Request
The value of this request attribute signifies the total number of bytes to transfer.
SEND_MESSAGE_INFRAGMENT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Attempting to send a message while sending fragments of another.
sendAcknowledgement() - Method in class org.glassfish.grizzly.http.server.Response
Send an acknowledgment of a request.
sendAcknowledgment(Request, Response) - Method in class org.glassfish.grizzly.http.server.HttpHandler
The default implementation will acknowledge an Expect: 100-Continue with a response line with the status 100 followed by the final response to this request.
sendBinary(ByteBuffer) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a binary message.
sendBinary(ByteBuffer, SendHandler) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a binary message.
sendBinary(ByteBuffer) - Method in interface javax.websocket.RemoteEndpoint.Basic
Send a binary message, returning when all of the message has been transmitted.
sendBinary(ByteBuffer, boolean) - Method in interface javax.websocket.RemoteEndpoint.Basic
Send a binary message in parts, blocking until all of the message has been transmitted.
sendBinary(String, byte[]) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send binary message.
sendBinary(String, byte[], boolean) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send partial binary message.
sendBinary(String, byte[], SendHandler) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send binary message with SendHandler.
sendBinary(byte[]) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Send a binary frame to the remote endpoint.
sendBinary(byte[], SendHandler) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Send a binary frame to the remote endpoint.
sendBinary(byte[], boolean) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sends a fragment of a complete message.
sendBinary(byte[], int, int, boolean) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sends a fragment of a complete message.
sendError(int) - Method in class org.glassfish.grizzly.http.server.Response
Send an error response with the specified status and a default message.
sendError(int, String) - Method in class org.glassfish.grizzly.http.server.Response
Send an error response with the specified status and message.
sendErrorPage(Request, Response, ErrorPageGenerator, int, String, String, Throwable) - Static method in class org.glassfish.grizzly.http.server.util.HtmlHelper
Generate and send an error page for the given HTTP response status.
sendfile(File, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Calls write(file, 0, file.length()).
sendfile(File, long, long, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
sendfile(File, long, long, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.http.server.io.ServerOutputBuffer
 
sendFile(Response, File) - Static method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
sendfileEnabled - Variable in class org.glassfish.grizzly.http.io.OutputBuffer
 
SendHandler - Interface in javax.websocket
A simple callback object for asynchronous sending of web socket messages.
sendObject(Object) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a custom developer object.
sendObject(Object, SendHandler) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a custom developer object.
sendObject(Object) - Method in interface javax.websocket.RemoteEndpoint.Basic
Sends a custom developer object, blocking until it has been transmitted.
sendPing(ByteBuffer) - Method in interface javax.websocket.RemoteEndpoint
Send a Ping message containing the given application data to the remote endpoint.
sendPing(String, byte[]) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send ping message.
sendPing(ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
sendPing(byte[]) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sends a ping frame with the specified payload (if any).
sendPong(ByteBuffer) - Method in interface javax.websocket.RemoteEndpoint
Allows the developer to send an unsolicited Pong message containing the given application data in order to serve as a unidirectional heartbeat for the session.
sendPong(String, byte[]) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send pong message.
sendPong(ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
sendPong(byte[]) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sends a ping frame with the specified payload (if any).
sendRawFrame(ByteBuffer) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
sendRawFrame(ByteBuffer) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Send a frame to the remote endpoint.
sendRedirect(String) - Method in class org.glassfish.grizzly.http.server.Response
Send a temporary redirect to the specified redirect location URL.
SendResult - Class in javax.websocket
The result of asynchronously sending a web socket message.
SendResult(Throwable) - Constructor for class javax.websocket.SendResult
Construct a SendResult carrying an exception.
SendResult() - Constructor for class javax.websocket.SendResult
Construct a SendResult signifying a successful send carrying no exception.
sendText(String, SendHandler) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a text message.
sendText(String) - Method in interface javax.websocket.RemoteEndpoint.Async
Initiates the asynchronous transmission of a text message.
sendText(String) - Method in interface javax.websocket.RemoteEndpoint.Basic
Send a text message, blocking until all of the message has been transmitted.
sendText(String, boolean) - Method in interface javax.websocket.RemoteEndpoint.Basic
Send a text message in parts, blocking until all of the message has been transmitted.
sendText(String, String) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send text message.
sendText(String, String, boolean) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send partial text message.
sendText(String, String, SendHandler) - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Send text message with SendHandler.
sendText(String) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Send a text frame to the remote endpoint.
sendText(String, SendHandler) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Send a text frame to the remote endpoint.
sendText(String, boolean) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sends a fragment of a complete message.
serializeClientCookies(StringBuilder, Cookie...) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeClientCookies(StringBuilder, boolean, boolean, Cookie...) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeClientCookies(Buffer, Cookie...) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeClientCookies(Buffer, boolean, Cookie...) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializePacket(FilterChainContext, HttpContent) - Method in class org.glassfish.grizzly.http.ChunkedTransferEncoding
Serialize HTTP packet payload, represented by HttpContent using specific transfer encoding.
serializePacket(FilterChainContext, HttpContent) - Method in class org.glassfish.grizzly.http.FixedLengthTransferEncoding
Serialize HTTP packet payload, represented by HttpContent using specific transfer encoding.
serializePacket(FilterChainContext, HttpContent) - Method in interface org.glassfish.grizzly.http.TransferEncoding
Serialize HTTP packet payload, represented by HttpContent using specific transfer encoding.
serializeServerCookie(StringBuilder, Cookie) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeServerCookie(StringBuilder, boolean, boolean, boolean, Cookie) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeServerCookie(StringBuilder, boolean, boolean, boolean, String, String, int, String, String, String, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeServerCookie(Buffer, Cookie) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeServerCookie(Buffer, boolean, boolean, Cookie) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeServerCookie(Buffer, boolean, boolean, String, String, int, String, String, String, int, boolean, boolean) - Static method in class org.glassfish.grizzly.http.util.CookieSerializerUtils
 
serializeToDataChunk(DataChunk) - Method in class org.glassfish.grizzly.http.util.ContentType
Serializes this ContentType value into a passed DataChunk.
serializeToDataChunk(DataChunk) - Method in class org.glassfish.grizzly.http.util.HeaderValue
Serializes this HeaderValue value into a passed DataChunk.
server() - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the server-side cookies builder with the specific "strict cookie version compliance".
server(boolean) - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the server-side cookies builder with the specific "strict cookie version compliance".
server(boolean, boolean) - Static method in class org.glassfish.grizzly.http.CookiesBuilder
Returns the server-side cookies builder with the specific "strict cookie version compliance".
server - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
SERVER_KEY_HASH - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
ServerApplicationConfig - Interface in javax.websocket.server
Developers include implementations of ServerApplicationConfig in an archive containing websocket endpoints (WAR file, or JAR file within the WAR file) in order to specify the websocket endpoints within the archive the implementation must deploy.
ServerConfiguration - Class in org.glassfish.grizzly.http.server
Configuration options for a particular HttpServer instance.
serverConnectionBackLog - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
serverConnections - Variable in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
The Server connections.
ServerContainer - Interface in javax.websocket.server
The ServerContainer is the specialized view of the WebSocketContainer available in server-side deployments.
ServerContainer - Interface in org.glassfish.tyrus.spi
HTTP server abstraction.
ServerContainerFactory - Class in org.glassfish.tyrus.spi
Factory used to get instances of ServerContainer.
ServerContainerFactory() - Constructor for class org.glassfish.tyrus.spi.ServerContainerFactory
 
ServerEndpoint - Annotation Type in javax.websocket.server
This class level annotation declares that the class it decorates is a web socket endpoint that will be deployed and made available in the URI-space of a web socket server.
ServerEndpointConfig - Interface in javax.websocket.server
The ServerEndpointConfig is a special kind of endpoint configuration object that contains web socket configuration information specific only to server endpoints.
ServerEndpointConfig.Builder - Class in javax.websocket.server
The ServerEndpointConfig.Builder is a class used for creating ServerEndpointConfig.Builder objects for the purposes of deploying a server endpoint.
ServerEndpointConfig.Configurator - Class in javax.websocket.server
The ServerEndpointConfig.Configurator class may be extended by developers who want to provide custom configuration algorithms, such as intercepting the opening handshake, or providing arbitrary methods and algorithms that can be accessed from each endpoint instance configured with this configurator.
ServerEndpointConfig.Configurator() - Constructor for class javax.websocket.server.ServerEndpointConfig.Configurator
 
ServerFilterConfiguration - Class in org.glassfish.grizzly.http.server
HttpServerFilter configuration.
ServerFilterConfiguration() - Constructor for class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
ServerFilterConfiguration(String, String) - Constructor for class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
ServerFilterConfiguration(ServerFilterConfiguration) - Constructor for class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
ServerInputBuffer - Class in org.glassfish.grizzly.http.server.io
Server-side implementation of the InputBuffer.
ServerInputBuffer() - Constructor for class org.glassfish.grizzly.http.server.io.ServerInputBuffer
 
serverName() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the buffer holding the server name, if any.
serverNameRaw() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Return the buffer holding the server name, if any.
ServerOutputBuffer - Class in org.glassfish.grizzly.http.server.io
 
ServerOutputBuffer() - Constructor for class org.glassfish.grizzly.http.server.io.ServerOutputBuffer
 
serverSocketSoTimeout - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
service(Request, Response) - Method in class org.glassfish.grizzly.http.server.HttpHandler
This method should contain the logic for any HTTP extension to the Grizzly HTTP web server.
service(Request, Response) - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
Map the Request to the proper HttpHandler
service(Request, Response) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
Based on the Request URI, try to map the file from the #getDocRoots(), and send it back to a client.
SERVICE_UNAVAILABLE_503 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
ServiceConfigurationError - Error in org.glassfish.grizzly.utils
Error thrown when something goes wrong while looking up service providers.
ServiceConfigurationError(String) - Constructor for error org.glassfish.grizzly.utils.ServiceConfigurationError
Constructs a new instance with the specified detail string.
ServiceConfigurationError(Throwable) - Constructor for error org.glassfish.grizzly.utils.ServiceConfigurationError
Constructs a new instance that wraps the specified throwable.
ServiceConfigurationError - Error in org.glassfish.tyrus.core
Taken from Jersey 2.
ServiceConfigurationError(String) - Constructor for error org.glassfish.tyrus.core.ServiceConfigurationError
Constructs a new instance with the specified detail string.
ServiceConfigurationError(Throwable) - Constructor for error org.glassfish.tyrus.core.ServiceConfigurationError
Constructs a new instance that wraps the specified throwable.
ServiceFinder<T> - Class in org.glassfish.grizzly.utils
A simple service-provider lookup mechanism.
ServiceFinder<T> - Class in org.glassfish.tyrus.core
A simple service-provider lookup mechanism.
ServiceFinder.DefaultServiceIteratorProvider - Class in org.glassfish.tyrus.core
The default service iterator provider that looks up provider classes in META-INF/services files.
ServiceFinder.DefaultServiceIteratorProvider() - Constructor for class org.glassfish.tyrus.core.ServiceFinder.DefaultServiceIteratorProvider
 
ServiceFinder.ServiceIteratorProvider - Class in org.glassfish.tyrus.core
Supports iteration of provider instances or classes.
ServiceFinder.ServiceIteratorProvider() - Constructor for class org.glassfish.tyrus.core.ServiceFinder.ServiceIteratorProvider
 
SERVLET_NAME_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward a servlet name to an error page.
servletName - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Wrapper
 
servletName - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
Session - Interface in javax.websocket
A Web Socket session represents a conversation between two web socket endpoints.
Session - Class in org.glassfish.grizzly.http.server
Simple session object.
Session() - Constructor for class org.glassfish.grizzly.http.server.Session
 
Session(String) - Constructor for class org.glassfish.grizzly.http.server.Session
Create a new session using a session identifier
SESSION_CLOSED_IDLE_TIMEOUT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
"Session closed by the container because of the idle timeout."
SESSION_COOKIE_NAME - Static variable in class org.glassfish.grizzly.http.server.Constants
The name of the cookie used to pass the session identifier back and forth with the client.
SESSION_COOKIE_NAME - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The name of the cookie used to pass the session identifier back and forth with the client.
SESSION_COOKIE_PATTERN - Static variable in class org.glassfish.grizzly.http.server.Constants
 
SESSION_ID_KEY - Static variable in interface org.glassfish.grizzly.ssl.SSLSupport
The Request attribute key for the session id.
SESSION_PARAMETER_NAME - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The name of the path parameter used to pass the session identifier back and forth with the client.
SessionEventListener - Class in org.glassfish.tyrus.core.cluster
Session event listener.
SessionEventListener(Session) - Constructor for class org.glassfish.tyrus.core.cluster.SessionEventListener
Constructor.
SessionException - Exception in javax.websocket
A SessionException represents a general exception type reporting problems occurring on a websocket session.
SessionException(String, Throwable, Session) - Constructor for exception javax.websocket.SessionException
Creates a new instance of this exception with the given message, the wrapped cause of the exception and the session with which the problem is associated.
SessionListener - Interface in org.glassfish.tyrus.core.cluster
Session listener.
sessionParsed - Variable in class org.glassfish.grizzly.http.server.Request
Session parsed flag.
set(Connection, Object, CompletionHandler) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
set(Connection, Object, CompletionHandler, Interceptor) - Method in class org.glassfish.grizzly.asyncqueue.AsyncReadQueueRecord
 
set(Connection, WritableMessage, CompletionHandler, Object, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
set(AttributeHolder, T) - Method in class org.glassfish.grizzly.attributes.Attribute
Set attribute value, stored on the AttributeHolder.
set(AttributeStorage, T) - Method in class org.glassfish.grizzly.attributes.Attribute
Set attribute value, stored on the AttributeStorage.
set(int, ProcessorSelector) - Method in class org.glassfish.grizzly.ChainProcessorSelector
set(int, Filter) - Method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
set(int, Filter) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
set(CompressionConfig) - Method in class org.glassfish.grizzly.http.CompressionConfig
Copies the source CompressionConfig object value into this object.
set(int, int, int, int) - Method in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
set(ByteChunk, Charset) - Method in class org.glassfish.grizzly.http.util.CharChunk
Set ByteChunk content to CharChunk using given Charset.
set(BufferChunk, Charset) - Method in class org.glassfish.grizzly.http.util.CharChunk
Set BufferChunk content to CharChunk using given Charset.
set(String) - Method in class org.glassfish.grizzly.http.util.ContentType
Sets the content type.
set(ContentType) - Method in class org.glassfish.grizzly.http.util.ContentType
Sets the content type.
set(ContentType) - Method in class org.glassfish.grizzly.http.util.ContentType.SettableContentType
 
set(String) - Method in class org.glassfish.grizzly.http.util.ContentType.SettableContentType
 
set(DataChunk) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
set(DataChunk, int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
set(byte) - Method in interface org.glassfish.grizzly.memory.CompositeBuffer.Setter
Set the current byte value.
set(Connection<L>, K, L, int) - Method in class org.glassfish.grizzly.ReadResult
One method to set all the WriteResult properties.
set(Connection<L>, K, L, long) - Method in class org.glassfish.grizzly.WriteResult
One method to set all the WriteResult properties.
setAccessibleMethod(Method) - Static method in class org.glassfish.tyrus.core.ReflectionHelper
Set a method to be accessible.
setAcknowledgement(boolean) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Mark this packet as an acknowledgment to a client expectation.
setAddress(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Set address, associated with the current IOEvent processing.
setAddressHolder(Holder<?>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Set address, associated with the current IOEvent processing.
setAlgorithm(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setAlgorithm(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setAllowCustomReasonPhrase(boolean) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Sets if the custom status reason phrases are allowed for this response.
setAllowCustomStatusMessage(boolean) - Method in class org.glassfish.grizzly.http.server.HttpHandler
Sets if the custom status messages (reason phrases) are allowed for this response.
setAllowDirectWrite(boolean) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Set true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
setAllowDirectWrite(boolean) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Set true, if async write queue is allowed to write buffer directly during write(...) method call, w/o adding buffer to the queue, or false otherwise.
setAllowEncodedSlash(boolean) - Method in class org.glassfish.grizzly.http.server.HttpHandler
When true, URL that contains encoded slash will be allowed.
setAllowEncodedSlash(boolean) - Method in class org.glassfish.grizzly.http.util.UDecoder
Override the default value
setAllowReplacement(boolean) - Static method in class org.glassfish.grizzly.http.server.util.Mapper
setAsyncEnabled(boolean) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Deprecated.
InputBuffer always supports async mode
setAsyncEnabled(boolean) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Deprecated.
OutputBuffer always supports async mode
setAsyncSendTimeout(long) - Method in interface javax.websocket.WebSocketContainer
Sets the number of milliseconds the implementation will timeout attempting to send a websocket message for all RemoteEndpoints associated with this container.
setAsyncSendTimeout(long) - Method in class org.glassfish.tyrus.client.ClientManager
 
setAttribute(String, Object) - Method in interface org.glassfish.grizzly.attributes.AttributeHolder
Set a name/value object.
setAttribute(int, Object) - Method in interface org.glassfish.grizzly.attributes.IndexedAttributeAccessor
Internal method for dynamic attribute support.
setAttribute(int, Object) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder.IndexedAttributeAccessorImpl
Internal method for dynamic attribute support.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.attributes.IndexedAttributeHolder
Set a name/value object.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the specified request attribute to the specified value.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.http.server.Request
Set the specified request attribute to the specified value.
setAttribute(String, Object) - Method in class org.glassfish.grizzly.http.server.Session
Add an attribute to this session.
setAttributeBuilder(AttributeBuilder) - Method in class org.glassfish.grizzly.AbstractTransport
Set Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
setAttributeBuilder(AttributeBuilder) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the AttributeBuilder to be used by the created NIOTransport.
setAttributeBuilder(AttributeBuilder) - Method in interface org.glassfish.grizzly.Transport
Set Transport associated AttributeBuilder, which will be used by Transport and its Connections to store custom Attributes.
setAuthPassThroughEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setBasePath(String) - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Sets the absolute doc base path of this AlternateDocBase.
setBatchingAllowed(boolean) - Method in interface javax.websocket.RemoteEndpoint
Indicate to the implementation that it is allowed to batch outgoing messages before sending.
setBatchingAllowed(boolean) - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
setBuffer(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
setBuffer(Buffer, MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
setBuffer(Buffer) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
setBuffer(Buffer, int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setBuffer(Buffer) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setBufferChunk(Buffer, int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
setBufferChunk(Buffer, int, int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
setBufferSize(int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
setBufferSize(int) - Method in class org.glassfish.grizzly.http.server.Response
Set the buffer size to be used for this Response.
setByteChunk(ByteChunk) - Method in class org.glassfish.grizzly.http.util.C2BConverter
 
setByteEnabled(boolean) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
setByteInputChannel(ByteChunk.ByteInputChannel) - Method in class org.glassfish.grizzly.http.util.ByteChunk
When the buffer is empty, read the data from the input channel.
setByteOutputChannel(ByteChunk.ByteOutputChannel) - Method in class org.glassfish.grizzly.http.util.ByteChunk
When the buffer is full, write the data to the output channel.
setBytes(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Sets the message bytes to the specified sub-array of bytes.
setBytes(byte[]) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setBytes(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setBytes(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Sets the content to the specified subarray of bytes.
setCacheSize(int) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
setCaseSenitive(boolean) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Configure the case sensitivity
setChannel(SelectableChannel) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setCharacterEncoding(String) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the character encoding of this HTTP message.
setCharacterEncoding(String) - Method in class org.glassfish.grizzly.http.server.Request
Overrides the name of the character encoding used in the body of this request.
setCharacterEncoding(String) - Method in class org.glassfish.grizzly.http.server.Response
 
setCharacterEncoding(String) - Method in class org.glassfish.grizzly.http.util.ContentType
Sets the the character encoding (the content-type's charset attribute value).
setCharacterEncoding(String) - Method in class org.glassfish.grizzly.http.util.ContentType.SettableContentType
 
setCharEnabled(boolean) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
setCharInputChannel(CharChunk.CharInputChannel) - Method in class org.glassfish.grizzly.http.util.CharChunk
When the buffer is empty, read the data from the input channel.
setCharOutputChannel(CharChunk.CharOutputChannel) - Method in class org.glassfish.grizzly.http.util.CharChunk
When the buffer is full, write the data to the output channel.
setChars(char[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
setChars(char[], int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setChars(char[], int, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Sets the content to be a char[]
setCharset(Charset) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
setCharset(Charset) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Set the encoding.
setCharset(Charset) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
setCharset(Charset) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
setChunked(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Set true, if this HttpPacket content will be transferred in chunking mode, or false if case of fixed-length message.
setChunkingAllowed(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Indicate whether or not chunking may be used by this header.
setChunkingEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Enable/disable chunking of an HTTP response body if no content length has been explictly specified.
setCipherConfigured(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setClientMode(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Set SSLEngine to be configured to work in client mode.
setClientSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setClientSocketSoTimeout(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setComment(String) - Method in class org.glassfish.grizzly.http.Cookie
Specifies a comment that describes a cookie's purpose.
setCommitted(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Is this HttpHeader written? true, if this HttpHeader has been already serialized, and only HttpContent messages might be serialized for this HttpPacket.
setCompletionHandler(CompletionHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
setCompressableMimeTypes(Set<String>) - Method in class org.glassfish.grizzly.http.CompressionConfig
Sets the set of the mime-types, which are allowed to be compressed.
setCompressableMimeTypes(String...) - Method in class org.glassfish.grizzly.http.CompressionConfig
Sets the set of the mime-types, which are allowed to be compressed.
setCompressedFilesFolder(File) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Sets the folder to be used to store temporary compressed files.
setCompressibleMimeTypes(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().setCompressableMimeTypes(Set<String>)
setCompression(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().setCompressionMode(mode)
setCompressionMinSize(int) - Method in class org.glassfish.grizzly.http.CompressionConfig
Sets the minimum size of an entity, which will be compressed.
setCompressionMinSize(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().setCompressionMinSize(int)
setCompressionMode(CompressionConfig.CompressionMode) - Method in class org.glassfish.grizzly.http.CompressionConfig
setConnection(Connection) - Method in class org.glassfish.grizzly.Context
Set the processing Connection.
setConnection(Connection) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
setConnectionForKey(NIOConnection, SelectionKey) - Method in class org.glassfish.grizzly.nio.DefaultSelectionKeyHandler
 
setConnectionForKey(NIOConnection, SelectionKey) - Method in interface org.glassfish.grizzly.nio.SelectionKeyHandler
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setConnectionTimeout(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setConnectResultHandler(TCPNIOConnection.ConnectResultHandler) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setContent(Buffer) - Method in class org.glassfish.grizzly.http.HttpContent
 
setContentBroken(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Set flag, which is set to true, means that HTTP packet payload was detected as broken due to unexpected error occurred during Transfer-Encoding or Content-Encoding processing.
setContentEncodingsSelected(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
 
setContentLanguage(String) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Set the value that will be used by the Content-Language response header.
setContentLength(int) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the length of this HTTP message.
setContentLength(int) - Method in class org.glassfish.grizzly.http.server.Response
Set the content length (in bytes) for this Response.
setContentLengthLong(long) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the content-length of this HttpPacket.
setContentLengthLong(long) - Method in class org.glassfish.grizzly.http.server.Response
Set the content length (in bytes) for this Response.
setContentType(String) - Method in class org.glassfish.grizzly.http.HttpHeader
Sets the content type.
setContentType(ContentType) - Method in class org.glassfish.grizzly.http.HttpHeader
Sets the content type.
setContentType(String) - Method in class org.glassfish.grizzly.http.server.Response
Set the content type for this Response.
setContentType(ContentType) - Method in class org.glassfish.grizzly.http.server.Response
Set the content type for this Response.
setContext(String, String[], NamingContext) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Set context, used for wrapper mapping (request dispatcher).
setContextPath(String) - Method in class org.glassfish.grizzly.http.server.Request
 
setContextPath(Request.PathResolver) - Method in class org.glassfish.grizzly.http.server.Request
 
setCookies(Cookie[]) - Method in class org.glassfish.grizzly.http.server.Request
Set the set of cookies received with this Request.
setCorePoolSize(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setCrc32(CRC32) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setCreationTime(long) - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
setCurrentElement(E) - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Set current task element.
setCustomTimeout(Connection, long, TimeUnit) - Static method in class org.glassfish.grizzly.utils.IdleTimeoutFilter
Provides an override mechanism for the default timeout.
setDaemon(boolean) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setData(Object) - Method in class org.glassfish.grizzly.ProcessorResult
 
setDateHeader(String, long) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified date header to the specified value.
setDateHeader(Header, long) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified date header to the specified value.
setDecodedURI(String) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
setDecoderProperties(byte[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.Decoder
 
setDecodeStatus(GZipDecoder.DecodeStatus) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setDecodeUrl(boolean) - Method in class org.glassfish.grizzly.http.server.HttpHandler
Should this class decode the URL
setDefaultContextPath(String, String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Configures the given virtual server with the given default context path.
setDefaultEncoding(String) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Set the default character encoding for this InputBuffer, which would be applied if no encoding was explicitly set on HTTP HttpRequestPacket and character decoding wasn't started yet.
setDefaultErrorPageGenerator(ErrorPageGenerator) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the NetworkListener default ErrorPageGenerator.
setDefaultErrorPageGenerator(ErrorPageGenerator) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the default ErrorPageGenerator.
setDefaultHostName(String) - Method in class org.glassfish.grizzly.http.server.util.Mapper
Set default host.
setDefaultMaxBinaryMessageBufferSize(int) - Method in interface javax.websocket.WebSocketContainer
Sets the default maximum size of incoming binary message that this container will buffer.
setDefaultMaxBinaryMessageBufferSize(int) - Method in class org.glassfish.tyrus.client.ClientManager
 
setDefaultMaxSessionIdleTimeout(long) - Method in interface javax.websocket.WebSocketContainer
Sets the default time in milliseconds after which any web socket sessions in this container will be closed if it has been inactive.
setDefaultMaxSessionIdleTimeout(long) - Method in class org.glassfish.tyrus.client.ClientManager
 
setDefaultMaxTextMessageBufferSize(int) - Method in interface javax.websocket.WebSocketContainer
Sets the maximum size of incoming text message that this container will buffer.
setDefaultMaxTextMessageBufferSize(int) - Method in class org.glassfish.tyrus.client.ClientManager
 
setDefaultQueryEncoding(Charset) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the default character encoding used to decode request URI's query part.
setDefaultResponseContentType(String) - Method in class org.glassfish.grizzly.http.HttpServerFilter
 
setDefaultURIEncoding(Charset) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
setDetailMessage(String) - Method in class org.glassfish.grizzly.http.server.Response
Sets detail error message.
setDictionarySize(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setDictionarySize(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setDirect(boolean) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Set true, if ByteBufferManager works with direct ByteBuffers, or false otherwise.
setDisableUploadTimeout(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setDispatcherHelper(DispatcherHelper) - Method in class org.glassfish.grizzly.http.server.HttpHandler
 
setDocBase(String) - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Sets the (possibly relative) doc base path of this AlternateDocBase.
setDomain(String) - Method in class org.glassfish.grizzly.http.Cookie
Specifies the domain within which this cookie should be presented.
setDst(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setDst(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setDstAddress(L) - Method in class org.glassfish.grizzly.WriteResult
Set the destination address, the message was written to.
setDstAddressHolder(Holder<L>) - Method in class org.glassfish.grizzly.WriteResult
Set the destination address, the message was written to.
setEmptyRecord(boolean) - Method in class org.glassfish.grizzly.asyncqueue.AsyncWriteQueueRecord
 
setEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Enables/disables the FileCache.
setEnabledCipherSuites(String[]) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setEnabledProtocols(String[]) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setEncoding(Charset) - Method in class org.glassfish.grizzly.http.util.Parameters
 
setEncoding(String) - Method in class org.glassfish.grizzly.http.util.UEncoder
 
setEnd(int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
setEnd(int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
setEnd(int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
setEnd(int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
setEnd(int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Sets the DataChunk end position.
setEndIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setEndMarkerMode(boolean) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setError(boolean) - Method in class org.glassfish.grizzly.http.ProcessingState
This flag indicates whether error occurred during the HTTP processing.
setError() - Method in class org.glassfish.grizzly.http.server.Response
Set the error flag.
setErrorAndSendErrorPage(Request, Response, ErrorPageGenerator, int, String, String, Throwable) - Static method in class org.glassfish.grizzly.http.server.util.HtmlHelper
Generate and send an error page for the given HTTP response status.
setErrorCode(int) - Method in class org.glassfish.grizzly.TransformationResult
 
setErrorDescription(String) - Method in class org.glassfish.grizzly.TransformationResult
 
setErrorPageGenerator(ErrorPageGenerator) - Method in class org.glassfish.grizzly.http.server.Response
setExpectContent(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
 
setExtensionContext(ExtendedExtension.ExtensionContext) - Method in class org.glassfish.tyrus.core.ProtocolHandler
Client side.
setExtensions(List<Extension>) - Method in class org.glassfish.tyrus.core.Handshake
Client side only - set the list of supported extensions.
setExtensions(List<Extension>) - Method in class org.glassfish.tyrus.core.ProtocolHandler
Client side.
setExternalRemainder(I) - Method in class org.glassfish.grizzly.TransformationResult
 
setFactory(MessageBytes.MessageBytesFactory) - Static method in class org.glassfish.grizzly.http.util.MessageBytes
 
setFailure(Throwable) - Method in class org.glassfish.tyrus.core.TyrusFuture
Sets the failure result of message writing process.
setFileCacheEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
Set true to configure this StaticHttpHandler to use file cache to serve static resources, or false otherwise.
setFileSendEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Configure whether or send-file support will enabled which allows sending File resources via FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel).
setFilterIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setFirst(K) - Method in class org.glassfish.grizzly.utils.Pair
 
setHandshakeTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
Sets the handshake timeout.
setHeader(String, String) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the value, of the specific HTTP mime header.
setHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the value, of the specific HTTP mime header.
setHeader(Header, String) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the value, of the specific HTTP mime header.
setHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the value, of the specific HTTP mime header.
setHeader(String, String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Set the value, of the specific HTTP mime header.
setHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpTrailer
Set the value, of the specific HTTP mime header.
setHeader(Header, String) - Method in class org.glassfish.grizzly.http.HttpTrailer
Set the value, of the specific HTTP mime header.
setHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.HttpTrailer
Set the value, of the specific HTTP mime header.
setHeader(String, String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Set the value, of the specific HTTP mime header.
setHeader(String, HeaderValue) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Set the value, of the specific HTTP mime header.
setHeader(Header, String) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Set the value, of the specific HTTP mime header.
setHeader(Header, HeaderValue) - Method in interface org.glassfish.grizzly.http.MimeHeadersPacket
Set the value, of the specific HTTP mime header.
setHeader(String, String) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified header to the specified value.
setHeader(String, HeaderValue) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified header to the specified value.
setHeader(Header, String) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified header to the specified value.
setHeader(Header, HeaderValue) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified header to the specified value.
setHeader(String, String) - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
 
setHeader(String, String) - Method in class org.glassfish.tyrus.spi.UpgradeResponse
Sets a response header with the given name and value.
setHeaderFlag(int) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setHeaderParsed(boolean) - Method in interface org.glassfish.grizzly.http.HttpPacketParsing
 
setHeaderParseStateValue(int) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setHeaders(MimeHeaders) - Method in class org.glassfish.grizzly.http.Cookies
 
setHeaders(MimeHeaders, boolean) - Method in class org.glassfish.grizzly.http.Cookies
 
setHeaders(MimeHeaders) - Method in class org.glassfish.grizzly.http.HttpTrailer
Set the mime headers.
setHeaders(MimeHeaders) - Method in class org.glassfish.grizzly.http.util.Parameters
 
setHeaderWritten(boolean) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setHtmlEncodingCustomReasonPhrase(boolean) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Sets if we need to encode HTML sensitive characters in custom reason phrase.
setHttpHandler(HttpHandler) - Method in class org.glassfish.grizzly.http.server.HttpServerFilter
 
setHttpHandlerPath(String) - Method in class org.glassfish.grizzly.http.server.Request
 
setHttpHandlerPath(Request.PathResolver) - Method in class org.glassfish.grizzly.http.server.Request
 
setHttpOnly(boolean) - Method in class org.glassfish.grizzly.http.Cookie
HttpOnly feature is used in server->client communication only to let client know, that the cookie can not be accessed on the client-side (script etc).
setHttpServerName(String) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the server name used for HTTP response headers and default generated error pages.
setHttpServerVersion(String) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the version of the server info sent in HTTP response headers and the default generated error pages.
setId(int) - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
setIdInternal(String) - Method in class org.glassfish.grizzly.http.server.Session
Return the session identifier for this session.
setIdleTimeoutInSeconds(int) - Method in class org.glassfish.grizzly.http.KeepAlive
Configures idle connection timeout behavior.
setImpl(ThreadPoolConfig) - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
setIncomingBufferSize(int) - Method in class org.glassfish.tyrus.core.TyrusWebSocketEngine
 
setInflater(Inflater) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setInitialClassLoader(ClassLoader) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Specifies the context classloader that will be used by threads in this pool.
setInitialized(boolean) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setInitialized(boolean) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder.GZipInputState
 
setInitialOutputBuffer(Buffer) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
setInt(int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Set the buffer to the representation of an int
setInterested(IOEvent, boolean) - Method in class org.glassfish.grizzly.filterchain.AbstractFilterChain
Set the the i/o event, this Processor is interested in
setInterested(IOEvent, boolean) - Method in interface org.glassfish.grizzly.Processor
Set the the i/o event, this Processor is interested in
setInterested(IOEvent, boolean) - Method in class org.glassfish.grizzly.StandaloneProcessor
Method does nothing.
setIntHeader(String, int) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified integer header to the specified value.
setIntHeader(Header, int) - Method in class org.glassfish.grizzly.http.server.Response
Set the specified integer header to the specified value.
setIoEvent(IOEvent) - Method in class org.glassfish.grizzly.Context
Set the processing IOEvent.
setIOStrategy(IOStrategy) - Method in class org.glassfish.grizzly.AbstractTransport
Set the IOStrategy implementation, which will be used by Transport to process IOEvent.
setIOStrategy(IOStrategy) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Changes the IOStrategy that will be used.
setIOStrategy(IOStrategy) - Method in interface org.glassfish.grizzly.Transport
Set the IOStrategy implementation, which will be used by Transport to process IOEvent.
setIteratorProvider(ServiceFinder.ServiceIteratorProvider) - Static method in class org.glassfish.tyrus.core.ServiceFinder
Register the service iterator provider to iterate on provider instances or classes.
setJmxEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Enables JMX for this HttpServer.
setKeepAlive(boolean) - Method in class org.glassfish.grizzly.http.ProcessingState
This flag controls the connection keep-alive feature.
setKeepAlive(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setKeepAlive(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setKeepAliveTime(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
The max period of time a thread will wait for a new task to process.
setKernelPool0(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
 
setKernelThreadPool(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
Set a thread pool which will run Transport internal tasks.
setKernelThreadPool(ExecutorService) - Method in interface org.glassfish.grizzly.Transport
Set a thread pool which will run Transport internal tasks.
setKernelThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.AbstractTransport
Set the ThreadPoolConfig to be used by the Transport internal thread pool.
setKernelThreadPoolConfig(ThreadPoolConfig) - Method in interface org.glassfish.grizzly.Transport
Set the ThreadPoolConfig to be used by the Transport internal thread pool.
setKeyManagerFactoryAlgorithm(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the key manager factory algorithm.
setKeyPass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of the key in the key store.
setKeyPass(char[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of the key in the key store.
setKeyStoreBytes(byte[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets key store payload as byte array.
setKeyStoreFile(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets key store file name, also makes sure that if other key store configuration parameters are not set to set them to default values.
setKeyStorePass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of key store.
setKeyStorePass(char[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of key store.
setKeyStoreProvider(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the key store provider name.
setKeyStoreType(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Type of key store.
setLast(boolean) - Method in class org.glassfish.grizzly.http.HttpContent
 
setLastResult(TransformationResult<K, L>) - Method in class org.glassfish.grizzly.AbstractTransformer.LastResultAwareState
 
setLc(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setLcLpPb(int, int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setLimit(int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Maximum amount of data in this buffer.
setLimit(int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Maximum amount of data in this buffer.
setLimit(int) - Method in class org.glassfish.grizzly.http.util.Parameters
 
setLinger(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setLinger(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setLocale(Locale) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Called explicitly by user to set the Content-Language and the default encoding
setLocale(Locale) - Method in class org.glassfish.grizzly.http.server.Response
Set the Locale that is appropriate for this response, including setting the appropriate character encoding.
setLocalHost(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the host name of the server servicing this request.
setLocalPort(int) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Sets the Internet Protocol (IP) port number of the interface on which the request was received.
setLocked(boolean) - Method in class org.glassfish.grizzly.http.server.util.ParameterMap
Set the locked state of this parameter map.
setLong(long) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Set the buffer to the representation of an long
setLp(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setManualIOEventControl() - Method in class org.glassfish.grizzly.Context
Switches processing to the manual IOEvent control.
setMatchFinder(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setMatchFinder(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setMaxAge(int) - Method in class org.glassfish.grizzly.http.Cookie
Sets the maximum age of the cookie in seconds.
setMaxAsyncWriteQueueSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the max size (in bytes) of asynchronous write queue associated with connection.
setMaxAsyncWriteQueueSize(int) - Method in class org.glassfish.grizzly.nio.NIOConnection
Set the max size (in bytes) of asynchronous write queue associated with connection.
setMaxAsyncWriteQueueSizeInBytes(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setMaxBinaryMessageBufferSize(int) - Method in interface javax.websocket.Session
Sets the maximum length of incoming binary messages that this Session can buffer.
setMaxBinaryMessageBufferSize(int) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Remote setters are not supported (yet?).
setMaxBinaryMessageBufferSize(int) - Method in class org.glassfish.tyrus.core.TyrusSession
 
setMaxBufferedPostSize(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the maximum POST body size, which can buffered in memory.
setMaxBufferedPostSize(int) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the maximum POST body size, which can buffered in memory.
setMaxCacheEntries(int) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Sets the maximum number of files that may be cached.
setMaxDispatchDepth(int) - Static method in class org.glassfish.grizzly.http.server.Request
Static setter method for the maximum dispatch depth
setMaxEntrySize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
The maximum size, in bytes, a resource may be before it can no longer be considered cacheable.
setMaxFormPostSize(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the maximum size of the POST body generated by an HTML form.
setMaxFormPostSize(int) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the maximum size of the POST body generated by an HTML form.
setMaxHttpHeaderSize(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Configures the maximum header size for an HTTP request.
setMaxIdleTimeout(long) - Method in interface javax.websocket.Session
Set the non-zero number of milliseconds before this session will be closed by the container if it is inactive, ie no messages are either sent or received.
setMaxIdleTimeout(long) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Remote setters are not supported (yet?).
setMaxIdleTimeout(long) - Method in class org.glassfish.tyrus.core.TyrusSession
 
setMaxInactiveInterval(long) - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
setMaxLargeFileCacheSize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Sets the maximum size, in bytes, of the memory mapped cache for large files.
setMaxNumHeaders(int) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
setMaxPendingBytes(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
The maximum size, in bytes, of all data waiting to be written to the associated Connection.
setMaxPendingBytesPerConnection(int) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Configures the maximum number of bytes pending to be written for a particular Connection.
setMaxPendingBytesPerConnection(int) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Configures the maximum number of bytes pending to be written for a particular Connection.
setMaxPendingBytesPerConnection(int) - Method in class org.glassfish.grizzly.ssl.SSLFilter
Configures the maximum number of bytes that may be queued to be written for a particular Connection.
setMaxPoolSize(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setMaxRequestHeaders(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the maximum number of headers allowed for a request.
setMaxRequestParameters(int) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the maximum number of parameters allowed for a request.
setMaxRequestsCount(int) - Method in class org.glassfish.grizzly.http.KeepAlive
Configures the max number of HTTP requests allowed to be processed on one keep-alive connection.
setMaxResponseHeaders(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the maximum number of headers allowed for a response.
setMaxSmallFileCacheSize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
The maximum size, in bytes, of the heap cache for files below the water mark set by FileCache.getMinEntrySize().
setMaxTextMessageBufferSize(int) - Method in interface javax.websocket.Session
Sets the maximum length of incoming text messages that this Session can buffer.
setMaxTextMessageBufferSize(int) - Method in class org.glassfish.tyrus.core.cluster.ClusterSession
Remote setters are not supported (yet?).
setMaxTextMessageBufferSize(int) - Method in class org.glassfish.tyrus.core.TyrusSession
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.AbstractTransformer
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.AbstractTransport
Set the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the MemoryManager to be used by the created NIOTransport.
setMemoryManager(MemoryManager) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setMemoryManager(MemoryManager) - Method in interface org.glassfish.grizzly.Transport
Set the Transport associated MemoryManager, which will be used by the Transport, its Connections and by during processing I/O events, occurred on Connections.
setMessage(Object) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueRecord
 
setMessage(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Set message object, associated with the current processing.
setMessage(K) - Method in class org.glassfish.grizzly.ReadResult
Set the message, which was read.
setMessage(O) - Method in class org.glassfish.grizzly.TransformationResult
 
setMessage(K) - Method in class org.glassfish.grizzly.WriteResult
Set the message, which was read.
setMessageCloner(MessageCloner) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
 
setMethod(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the HTTP request method.
setMethod(Method) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the HTTP request method.
setMethod(String) - Method in class org.glassfish.grizzly.http.server.Request
Sets the HTTP request method used in this Request.
setMimeType(String) - Method in class org.glassfish.grizzly.http.util.ContentType
Sets the mime-type part of the content-type (the part without charset attribute).
setMimeType(String) - Method in class org.glassfish.grizzly.http.util.ContentType.SettableContentType
 
setMinEntrySize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
The maximum size, in bytes, a file must be in order to be cached in the heap cache.
setName(String) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the Transport name.
setName(String) - Method in class org.glassfish.grizzly.http.Cookie
 
setName(String) - Method in class org.glassfish.grizzly.http.server.ServerConfiguration
Sets the logical name of this HttpServer instance.
setName(String) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setName(String) - Method in interface org.glassfish.grizzly.Transport
Sets the Transport name.
setNeedClientAuth(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setNew(boolean) - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
setNewConnectionFilterChain(FilterChain) - Method in class org.glassfish.grizzly.ssl.SSLConnectionContext
 
setNIOChannelDistributor(NIOChannelDistributor) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setNIOChannelDistributor(NIOChannelDistributor) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the NIOChannelDistributor to be used by the created NIOTransport.
setNoCompressionUserAgents(Set<String>) - Method in class org.glassfish.grizzly.http.CompressionConfig
Sets the set of the user-agents, which will be always responded with uncompressed data.
setNoCompressionUserAgents(String...) - Method in class org.glassfish.grizzly.http.CompressionConfig
Sets the set of the user-agents, which will be always responded with uncompressed data.
setNoCompressionUserAgents(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Deprecated.
use getCompressionConfig().setNoCompressionUserAgents(Set<String>)
setNote(Note<E>, E) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Bind the Note value to this Request, replacing any existing binding for this name.
setNote(Note<E>, E) - Method in class org.glassfish.grizzly.http.server.Request
Bind the Note value to this Request, replacing any existing binding for this name.
setNumFastBytes(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
setNumFastBytes(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setOffset(int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
setOptimizedForMultiplexing(boolean) - Method in class org.glassfish.grizzly.nio.NIOTransport
Configures NIOTransport to be optimized for specific for the connection multiplexing usecase, when different threads will try to write data simultaneously.
setOptimizedForMultiplexing(boolean) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setOptimizedWrite(boolean) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
setOptimizedWrite(boolean) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
setParent(Object) - Method in class org.glassfish.grizzly.http.util.TimeStamp
Returns the owner of this stamp ( the object that is time-stamped ).
setPassTraceRequest(boolean) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
If passTraceRequest is true, the TRACE request will be passed to the registered HttpHandlers.
setPath(String) - Method in class org.glassfish.grizzly.http.Cookie
Specifies a path for the cookie to which the client should return the cookie.
setPathInfo(String) - Method in class org.glassfish.grizzly.http.server.Request
 
setPathInfo(Request.PathResolver) - Method in class org.glassfish.grizzly.http.server.Request
 
setPb(int) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAProperties
 
setPoolName(String) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setPort(int) - Method in class org.glassfish.grizzly.http.server.util.Mapper
The Port this instance is used for mapping.
setPositionLimit(E, int, int) - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
setPositionLimit(Buffer, int, int) - Method in class org.glassfish.grizzly.memory.BufferArray
 
setPositionLimit(Buffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
setPositionLimit(ByteBuffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
setPositionLimit(ByteBuffer, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferArray
 
setPriority(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setProcessor(Processor) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Set the default Processor to process IOEvent, occurring on connection phase.
setProcessor(Processor) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Set the default Processor to process IOEvent, occurring on connection phase.
setProcessor(Processor) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
setProcessor(Processor) - Method in interface org.glassfish.grizzly.Connection
Sets the default Processor, which will process Connection I/O events.
setProcessor(Processor) - Method in class org.glassfish.grizzly.Context
Set the Processor, which is responsible to process the IOEvent.
setProcessor(Processor) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setProcessor(Processor) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setProcessor(Processor) - Method in interface org.glassfish.grizzly.Transport
Sets the default Processor, which will process Connection I/O events in case, if Connection doesn't have own Processor preferences.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractBindingHandler
Sets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractSocketConnectorHandler
Sets the default ProcessorSelector, which will be used to get Processor to process I/O events, occurring on connection phase.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.AbstractTransport
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
setProcessorSelector(ProcessorSelector) - Method in interface org.glassfish.grizzly.Connection
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Connection's Processor is null.
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setProcessorSelector(ProcessorSelector) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setProcessorSelector(ProcessorSelector) - Method in interface org.glassfish.grizzly.Transport
Sets the default ProcessorSelector, which will be used to get Processor to process Connection I/O events, in case if this Transport's Processor is null and Connection doesn't have neither preferred Processor nor ProcessorSelector.
setProtocol(Protocol) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the HTTP message protocol version.
setProtocolConfigured(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setPushBackHandler(PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext.TransportContext
Deprecated.
setQuery(DataChunk) - Method in class org.glassfish.grizzly.http.util.Parameters
 
setQueryString(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the query portion of the request URI.
setQueryString(String) - Method in class org.glassfish.grizzly.http.server.Request
Sets the query string associated with this request.
setQueryStringEncoding(Charset) - Method in class org.glassfish.grizzly.http.util.Parameters
 
setQueue(Queue<Runnable>) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setQueueLimit(int) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.AbstractTransport
Set the default size of Buffers, which will be allocated for reading data from Transport's Connections.
setReadBufferSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the default size of Buffers, which will be allocated for reading data from Connection.
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Set the default size of Buffers, which will be allocated for reading data from Connection.
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
setReadBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Set the default size of Buffers, which will be allocated for reading data from Connection.
setReadBufferSize(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setReadBufferSize(int) - Method in interface org.glassfish.grizzly.Transport
Set the default size of Buffers, which will be allocated for reading data from Transport's Connections.
setReader(AsyncQueueReader<L>) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
 
setReadSize(int) - Method in class org.glassfish.grizzly.ReadResult
Set the number of bytes, which were read.
setReadTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.AbstractTransport
Specifies the timeout for the blocking reads.
setReadTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Connection
Specifies the timeout for the blocking reads.
setReadTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setReadTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setReadTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Transport
Specifies the timeout for the blocking reads.
setReasonPhrase(String) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Sets the status reason phrase for this response.
setReasonPhrase(Buffer) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
 
setReasonPhrase(String) - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
Set HTTP reason phrase.
setReasonPhrase(String) - Method in class org.glassfish.tyrus.spi.UpgradeResponse
Get HTTP reason phrase.
setRemotePort(int) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Sets the Internet Protocol (IP) source port of the client or last proxy that sent the request.
setRequest(HttpRequestPacket) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Associates the request that triggered this response.
setRequestedSessionCookie(boolean) - Method in class org.glassfish.grizzly.http.server.Request
Set a flag indicating whether or not the requested session ID for this request came in through a cookie.
setRequestedSessionId(String) - Method in class org.glassfish.grizzly.http.server.Request
Set the requested session ID for this request.
setRequestedSessionURL(boolean) - Method in class org.glassfish.grizzly.http.server.Request
Set a flag indicating whether or not the requested session ID for this request came in through a URL.
setRequestExecutorProvider(RequestExecutorProvider) - Method in class org.glassfish.grizzly.http.server.Request
Sets @return the RequestExecutorProvider responsible for executing user's code in HttpHandler.service(org.glassfish.grizzly.http.server.Request, org.glassfish.grizzly.http.server.Response) and notifying ReadHandler, WriteHandler registered by the user.
setRequestParameters(Parameters) - Method in class org.glassfish.grizzly.http.server.Request
This method may be used if some other entity processed request parameters and wishes to expose them via the request.
setRequestURI(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Set the request URL.
setRequestURI(String) - Method in class org.glassfish.grizzly.http.server.Request
Sets the request URI for this request.
setRequestURIEncoding(Charset) - Method in class org.glassfish.grizzly.http.server.HttpHandler
Set the request URI encoding used by this HttpHandler.
setRequestURIEncoding(String) - Method in class org.glassfish.grizzly.http.server.HttpHandler
Set the request URI encoding used by this HttpHandler.
setResources(DirContext) - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Sets the proxied resources of this AlternateDocBase.
setResponse(HttpResponsePacket) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
 
setRestrictedUserAgents(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setResult(R) - Method in class org.glassfish.grizzly.impl.ReadyFutureImpl
Should not be called for ReadyFutureImpl
setResult(E) - Method in interface org.glassfish.grizzly.utils.ResultAware
 
setResult(T) - Method in class org.glassfish.tyrus.core.TyrusFuture
Sets the result of the message writing process.
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
setReuseAddress(boolean) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setReuseSessionID(boolean) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Sets the "reuse session IDs when creating sessions"
setScheme(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Set the HTTP request scheme, which if non-null overrides default one picked up by framework during runtime.
setScheme(String) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Set the HTTP request scheme, which if non-null overrides default one picked up by framework during runtime.
setSecond(L) - Method in class org.glassfish.grizzly.utils.Pair
 
setSecondsMaxAge(int) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
Sets the maximum time, in seconds, a file may be cached.
setSecure(boolean) - Method in class org.glassfish.grizzly.http.Cookie
Indicates to the browser whether the cookie should only be sent using a secure protocol, such as HTTPS or SSL.
setSecure(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Sets the secure status of this HTTP message.
setSecure(boolean) - Method in class org.glassfish.grizzly.http.LazyCookieState
 
setSecure(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Enable or disable security for this listener.
setSecurityProtocol(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the SSLContext protocol.
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setSelectionKey(SelectionKey) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setSelectionKeyHandler(SelectionKeyHandler) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectionKeyHandler(SelectionKeyHandler) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectionKeyHandler to be used by the created NIOTransport.
setSelectorHandler(SelectorHandler) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectorHandler(SelectorHandler) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectorHandler to be used by the created NIOTransport.
setSelectorPool(TemporarySelectorPool) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
setSelectorProvider(SelectorProvider) - Method in class org.glassfish.grizzly.nio.NIOTransport
Set the SelectorProvider to be used by this transport.
setSelectorProvider(SelectorProvider) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Set the SelectorProvider to be used by the created NIOTransport.
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
setSelectorRunner(SelectorRunner) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
setSelectorRunnersCount(int) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setSelectorThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Sets the ThreadPoolConfig that will be used to construct the ExecutorService which will run the NIOTransport's SelectorRunners.
setSendFileEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setSendFileEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
Configure whether or sendfile support will enabled which allows sending File resources via FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel).
setSendTimeout(long) - Method in interface javax.websocket.RemoteEndpoint.Async
Sets the number of milliseconds the implementation will timeout attempting to send a websocket message.
setSerialized(int, boolean) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Set the header's "serialized" flag.
setServerConnectionBackLog(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Set the default server connection backlog size.
setServerConnectionBackLog(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setServerName(String) - Method in class org.glassfish.grizzly.http.server.Request
Set the name of the server (virtual host) to process this request.
setServerPort(int) - Method in class org.glassfish.grizzly.http.HttpRequestPacket
Sets the Internet Protocol (IP) port specified in the Host request header.
setServerPort(int) - Method in class org.glassfish.grizzly.http.server.Request
Set the port number of the server to process this request.
setServerSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.NIOTransport
 
setServerSocketSoTimeout(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setService(boolean) - Static method in class org.glassfish.grizzly.threadpool.Threads
 
setSessionTimeout(long) - Method in class org.glassfish.grizzly.http.server.Session
Set a long representing the maximum idle time (in milliseconds) a session can be.
setSize(int) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
setSkipRemainder(boolean) - Method in class org.glassfish.grizzly.http.HttpHeader
Set flag, which is set to true, means that we're not interested in parsing the rest of this HTTP message content and wait for the next HTTP message to come on this Connection.
setSrc(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
setSrc(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder.LZMAOutputState
 
setSrcAddress(L) - Method in class org.glassfish.grizzly.ReadResult
Set the source address, the message was read from.
setSrcAddressHolder(Holder<L>) - Method in class org.glassfish.grizzly.ReadResult
Set the source address, the message was read from.
setSSLEngine(Connection, SSLEngine) - Static method in class org.glassfish.grizzly.ssl.SSLUtils
 
setSSLEngineConfig(SSLEngineConfigurator) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Provides customization of the SSLEngine used by this listener.
setStart(int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
setStart(int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
setStart(int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns the start offset of the bytes.
setStart(int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
setStart(int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Sets the DataChunk start position.
setStartIdx(int) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
setState(E) - Method in class org.glassfish.grizzly.utils.StateHolder
Sets current state Current StateHolder locking mode will be used
setStatus(int) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Sets the status code for this response.
setStatus(HttpStatus) - Method in class org.glassfish.grizzly.http.HttpResponsePacket
Sets the status code for this response.
setStatus(int) - Method in class org.glassfish.grizzly.http.server.Response
Set the HTTP status to be returned with this response.
setStatus(int, String) - Method in class org.glassfish.grizzly.http.server.Response
Set the HTTP status and message to be returned with this response.
setStatus(HttpStatus) - Method in class org.glassfish.grizzly.http.server.Response
Set the HTTP status and message to be returned with this response.
setStatus(ProcessorResult.Status) - Method in class org.glassfish.grizzly.ProcessorResult
 
setStatus(TransformationResult.Status) - Method in class org.glassfish.grizzly.TransformationResult
 
setStatus(int) - Method in class org.glassfish.tyrus.core.TyrusUpgradeResponse
Set HTTP status.
setStatus(int) - Method in class org.glassfish.tyrus.spi.UpgradeResponse
Sets HTTP status code for this response.
setString(String) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Set the String we are currently parsing.
setString(String) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
setString(String) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Set the content to be a string
setSubProtocols(List<String>) - Method in class org.glassfish.tyrus.core.Handshake
Client side only - set the list of supported subprotocols.
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
setSyncConnectTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
setTcpNoDelay(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
setTcpNoDelay(boolean) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
setThreadFactory(ThreadFactory) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.http.server.Response.SuspendedContextImpl
 
setTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.http.server.SuspendContext
Set the suspended Response timeout.
setTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Set the timeout for StreamWriter I/O operations.
setTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Set the timeout for StreamWriter I/O operations.
setTimeoutMillis(E, long) - Method in interface org.glassfish.grizzly.utils.DelayedExecutor.Resolver
 
setTimestamp(long) - Method in class org.glassfish.grizzly.http.server.Session
Set the timestamp when this session has been created.
setTraceEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setTraceEnabled(boolean) - Method in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
If enabled is true the TRACE method will be respected and a proper response will be generated.
setTrackingThreadCache(boolean) - Static method in class org.glassfish.grizzly.Grizzly
 
setTrainThreshold(int) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
setTransactionMonitor(DelayedExecutor) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
Sets the time, in seconds, within which a request must complete its processing.
setTransactionTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
 
setTransactionTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(DelayedExecutor, long, TimeUnit) - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
setTransactionTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
setTransferEncoding(TransferEncoding) - Method in class org.glassfish.grizzly.http.HttpHeader
Set the TransferEncoding, responsible for the parsing/serialization of the HTTP message content.
setTransport(TCPNIOTransport) - Method in class org.glassfish.grizzly.http.server.NetworkListener
This allows the developer to specify a custom TCPNIOTransport implementation to be used by this listener.
setTransport(TCPNIOTransport) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
setTransport(UDPNIOTransport) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
setTrustManagerFactoryAlgorithm(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the trust manager factory algorithm.
setTrustStoreBytes(byte[]) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets trust store payload as byte array.
setTrustStoreFile(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets trust store file name, also makes sure that if other trust store configuration parameters are not set to set them to default values.
setTrustStorePass(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Password of trust store.
setTrustStoreProvider(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Sets the trust store provider name.
setTrustStoreType(String) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Type of trust store.
setType(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
setup(NetworkListener, FilterChainBuilder) - Method in interface org.glassfish.grizzly.http.server.AddOn
The method, which will be invoked by HttpServer in order to initialize the AddOn on the passed NetworkListener.
setup(NetworkListener, FilterChainBuilder) - Method in class org.glassfish.grizzly.http.server.util.AggregatorAddOn
The method, which will be invoked by HttpServer in order to initialize the AddOn on the passed NetworkListener.
setup(NetworkListener, FilterChainBuilder) - Method in class org.glassfish.grizzly.http.server.util.HttpPipelineOptAddOn
 
setUpgrade(String) - Method in class org.glassfish.grizzly.http.HttpHeader
 
setUploadTimeout(int) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setURI(String) - Method in class org.glassfish.grizzly.http.util.RequestURIRef
 
setUriEncoding(String) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
setUrlPattern(String) - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Sets the url pattern of this AlternateDocBase.
setUserPrincipal(Principal) - Method in class org.glassfish.grizzly.http.server.Request
Set the Principal who has been authenticated for this Request.
setValid(boolean) - Method in class org.glassfish.grizzly.http.server.Session
Set this object as validated.
setValid(boolean) - Method in class org.glassfish.grizzly.http.util.TimeStamp
 
setValue(String) - Method in class org.glassfish.grizzly.http.Cookie
Assigns a new value to a cookie after the cookie is created.
setValue(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Allow "set" operations - return a DataChunk container for the header value ( existing header or new if this .
setValue(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Allow "set" operations - return a DataChunk container for the header value ( existing header or new if this .
setValues(HttpResponsePacket) - Method in class org.glassfish.grizzly.http.util.HttpStatus
Sets the status and reason phrase on the specified response.
setVersion(int) - Method in class org.glassfish.grizzly.http.Cookie
Sets the version of the cookie protocol this cookie complies with.
setWantClientAuth(boolean) - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
setWebappResources(DirContext) - Method in class org.glassfish.grizzly.http.server.util.AlternateDocBase
Sets the non-proxied resources of this AlternateDocBase.
setWebSocket(TyrusWebSocket) - Method in class org.glassfish.tyrus.core.ProtocolHandler
Client side.
setWorkerThreadPool(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
Set a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
setWorkerThreadPool(ExecutorService) - Method in interface org.glassfish.grizzly.Transport
Set a thread pool, which will run IOEvent processing (depending on Transport IOStrategy) to let kernel threads continue their job.
setWorkerThreadPool0(ExecutorService) - Method in class org.glassfish.grizzly.AbstractTransport
 
setWorkerThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.AbstractTransport
Set the ThreadPoolConfig to be used by the worker thread pool.
setWorkerThreadPoolConfig(ThreadPoolConfig) - Method in class org.glassfish.grizzly.NIOTransportBuilder
Sets the ThreadPoolConfig that will be used to construct the ExecutorService for IOStrategies that require worker threads
setWorkerThreadPoolConfig(ThreadPoolConfig) - Method in interface org.glassfish.grizzly.Transport
Set the ThreadPoolConfig to be used by the worker thread pool.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.AbstractTransport
Set the default size of Buffers, which will be allocated for writing data to Transport's Connections.
setWriteBufferSize(int) - Method in interface org.glassfish.grizzly.Connection
Set the default size of Buffers, which will be allocated for writing data to Connection.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
Set the default size of Buffers, which will be allocated for writing data to Connection.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Set the default size of Buffers, which will be allocated for writing data to Connection.
setWriteBufferSize(int) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setWriteBufferSize(int) - Method in interface org.glassfish.grizzly.Transport
Set the default size of Buffers, which will be allocated for writing data to Transport's Connections.
setWriter(AsyncQueueWriter<L>) - Method in class org.glassfish.grizzly.asyncqueue.AsyncQueueIO.MutableAsyncQueueIO
 
setWriter(Writer) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
setWriteTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.AbstractTransport
Specifies the timeout for the blocking writes.
setWriteTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Connection
Specifies the timeout for the blocking writes.
setWriteTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
setWriteTimeout(long, TimeUnit) - Method in class org.glassfish.grizzly.NIOTransportBuilder
 
setWriteTimeout(long, TimeUnit) - Method in interface org.glassfish.grizzly.Transport
Specifies the timeout for the blocking writes.
setWriteTimeout(long) - Method in class org.glassfish.tyrus.core.TyrusWebSocket
Sets the timeout for the writing operation.
setWrittenSize(long) - Method in class org.glassfish.grizzly.WriteResult
Set the number of bytes, which were written.
SEVERE_GRIZZLY_COMET_ENGINE_INVALID_NOTIFICATION_HANDLER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0103: Invalid NotificationHandler class [{0}].
SEVERE_GRIZZLY_CONFIG_SSL_CLASS_LOAD_FAILED_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0054: Unable to load class: {0}.
SEVERE_GRIZZLY_CONFIG_SSL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0055: Can not configure SSLImplementation.
SHARED_CONTAINER - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientContainer
When set to true (boolean value), client runtime preserves used container and reuses it for outgoing connections.
SHARED_CONTAINER_IDLE_TIMEOUT - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientContainer
Container idle timeout in seconds (Integer value).
shiftLow() - Method in class org.glassfish.grizzly.compression.lzma.impl.rangecoder.RangeEncoder
 
shrink() - Method in interface org.glassfish.grizzly.Buffer
Disposes the buffer part, outside [position, limit] interval if possible.
shrink() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
shrink() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
shrink() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
shutdown(long, TimeUnit) - Method in class org.glassfish.grizzly.http.server.HttpServer
 
shutdown() - Method in class org.glassfish.grizzly.http.server.HttpServer
Gracefully shuts down the HttpServer instance.
shutdown(long, TimeUnit) - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
shutdown() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Gracefully shuts down the listener.
shutdown() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
shutdown(long, TimeUnit) - Method in class org.glassfish.grizzly.nio.NIOTransport
Gracefully stops the transport accepting new connections and allows existing work to complete before finalizing the shutdown.
shutdown() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
shutdown() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
shutdown() - Method in interface org.glassfish.grizzly.Transport
Gracefully stops the transport accepting new connections and allows existing work to complete before finalizing the shutdown.
shutdown(long, TimeUnit) - Method in interface org.glassfish.grizzly.Transport
Gracefully stops the transport accepting new connections and allows existing work to complete before finalizing the shutdown.
shutdown() - Method in class org.glassfish.tyrus.core.BaseContainer
Release executor services managed by this instance.
shutdown() - Method in class org.glassfish.tyrus.core.cluster.ClusterContext
Shutdown this ClusterContext.
ShutdownContext - Interface in org.glassfish.grizzly
This class will be passed to GracefulShutdownListener instances registered against a Transport.
shutdownForced() - Method in interface org.glassfish.grizzly.GracefulShutdownListener
Invoked when the transport is being shutdown forcefully.
shutdownFuture - Variable in class org.glassfish.grizzly.nio.NIOTransport
Future to control graceful shutdown status
shutdownListeners - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
shutdownNow() - Method in class org.glassfish.grizzly.http.server.HttpServer
Immediately shuts down the HttpServer instance.
shutdownNow() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Immediately shuts down the listener.
shutdownNow() - Method in class org.glassfish.grizzly.nio.NIOTransport
Forcibly stops the transport and closes all connections.
shutdownNow() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
shutdownNow() - Method in class org.glassfish.grizzly.threadpool.GrizzlyExecutorService
 
shutdownNow() - Method in interface org.glassfish.grizzly.Transport
Forcibly stops the transport and closes all connections.
shutdownRequested(ShutdownContext) - Method in interface org.glassfish.grizzly.GracefulShutdownListener
Invoked when an attempt is made to shutdown the transport gracefully.
shutdownService - Variable in class org.glassfish.grizzly.nio.NIOTransport
ExecutorService hosting shutdown listener threads.
SilentConnectionFilter - Class in org.glassfish.grizzly.utils
Filter, which determines silent connections and closes them.
SilentConnectionFilter(DelayedExecutor, long, TimeUnit) - Constructor for class org.glassfish.grizzly.utils.SilentConnectionFilter
 
SimpleDateFormats - Class in org.glassfish.grizzly.http.server.util
 
SimpleDateFormats() - Constructor for class org.glassfish.grizzly.http.server.util.SimpleDateFormats
 
SimpleDynamicNIOStrategy - Class in org.glassfish.grizzly.strategies
Simple dynamic strategy, which switches I/O processing strategies, basing on statistics.
simulateIOEvent(IOEvent) - Method in interface org.glassfish.grizzly.Connection
 
simulateIOEvent(IOEvent) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
size() - Method in class org.glassfish.grizzly.asyncqueue.PushBackContext
Deprecated.
Returns the message size.
size() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Returns the number of queued bytes.
size() - Method in class org.glassfish.grizzly.ChainProcessorSelector
size() - Method in class org.glassfish.grizzly.Context.MinimalisticArrayList
 
size() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
size() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
Returns the current number of header fields.
size() - Method in class org.glassfish.grizzly.memory.AbstractBufferArray
 
size() - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
size() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
size() - Method in interface org.glassfish.grizzly.streams.Input
 
size() - Method in class org.glassfish.grizzly.streams.StreamInput
 
size() - Method in class org.glassfish.grizzly.utils.ArraySet
size() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Returns the number of elements in this queue.
size() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
skip(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.lz.BinTree
 
skip(long, boolean) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Deprecated.
pls. use InputBuffer.skip(long), the block parameter will be ignored
skip(long) - Method in class org.glassfish.grizzly.http.io.InputBuffer
Skips the specified number of bytes/characters.
skip(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
 
skip(int) - Method in class org.glassfish.grizzly.streams.BufferedInput
 
skip(int) - Method in interface org.glassfish.grizzly.streams.Input
 
skip(int) - Method in class org.glassfish.grizzly.streams.StreamInput
 
skip(int) - Method in interface org.glassfish.grizzly.streams.StreamReader
 
skip(long) - Method in class org.glassfish.grizzly.utils.BufferInputStream
skipChar(char) - Method in class org.glassfish.grizzly.http.server.util.StringParser
Advance the current parsing position while it is pointing at the specified character, or until it moves past the end of the string.
skipPostBody(int) - Method in class org.glassfish.grizzly.http.server.Request
Skips the POST body of this request.
skipSpaces(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
skipSpaces(byte[], int, int, int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
 
skipText() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Advance the current parsing position while it is pointing at a non-whitespace character, or until it moves past the end of the string.
skipWhite() - Method in class org.glassfish.grizzly.http.server.util.StringParser
Advance the current parsing position while it is pointing at a whitespace character, or until it moves past the end of the string.
slice() - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer whose content is a shared subsequence of this buffer's content.
slice(int, int) - Method in interface org.glassfish.grizzly.Buffer
Creates a new Buffer whose content is a shared subsequence of this buffer's content.
slice(ByteBuffer, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Slice ByteBuffer of required size from big chunk.
slice(ByteBuffer, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Get the ByteBuffer's slice basing on its passed position and limit.
slice() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
slice() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
slice() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
slice(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
sliceBuffer() - Method in class org.glassfish.grizzly.nio.DirectByteBufferRecord
 
SOCKET_NOT_CONNECTED() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Socket is not connected.
SocketAcceptor - Interface in org.glassfish.grizzly
Common interface for SocketAcceptor implementations.
SocketBinder - Interface in org.glassfish.grizzly
Common API for Socket based Transports, which are able to bind server Socket to specific address and listen for incoming data.
SocketConnectorHandler - Interface in org.glassfish.grizzly
Socket based client side connector.
SP - Static variable in class org.glassfish.grizzly.http.server.Constants
SP.
SP - Static variable in class org.glassfish.grizzly.http.util.Constants
SP.
spaceInBytes() - Method in class org.glassfish.grizzly.asyncqueue.TaskQueue
Returns the number of queued bytes.
split(int) - Method in interface org.glassfish.grizzly.Buffer
Split up the buffer into two parts: [0..splitPosition) and [splitPosition, capacity).
split(int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
split(int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
split(int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Split up the buffer into two parts: [0..splitPosition) and [splitPosition, capacity).
SSL_CERTIFICATE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
SSL Certificate Request Attributite.
SSL_ENGINE_CONFIGURATOR - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientContainer
 
SSLBaseFilter - Class in org.glassfish.grizzly.ssl
SSL Filter to operate with SSL encrypted data.
SSLBaseFilter() - Constructor for class org.glassfish.grizzly.ssl.SSLBaseFilter
 
SSLBaseFilter(SSLEngineConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLBaseFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLBaseFilter(SSLEngineConfigurator, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLBaseFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLBaseFilter.CertificateEvent - Class in org.glassfish.grizzly.ssl
 
SSLBaseFilter.CertificateEvent(boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLBaseFilter.CertificateEvent
 
SSLBaseFilter.HandshakeListener - Interface in org.glassfish.grizzly.ssl
 
SSLCodec - Class in org.glassfish.grizzly.ssl
SSL Codec, which contains SSL encoder and decoder Transformers.
SSLCodec(SSLContextConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLCodec
 
SSLCodec(SSLContext) - Constructor for class org.glassfish.grizzly.ssl.SSLCodec
 
SSLConnectionContext - Class in org.glassfish.grizzly.ssl
SSL context associated with a Connection.
SSLConnectionContext(Connection) - Constructor for class org.glassfish.grizzly.ssl.SSLConnectionContext
 
sslContext - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
sslContextConfiguration - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLContextConfigurator - Class in org.glassfish.grizzly.ssl
Utility class, which helps to configure SSLContext.
SSLContextConfigurator() - Constructor for class org.glassfish.grizzly.ssl.SSLContextConfigurator
Default constructor.
SSLContextConfigurator(boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLContextConfigurator
Constructor that allows you creating empty configuration.
SSLDecoderTransformer - Class in org.glassfish.grizzly.ssl
Transformer, which decodes SSL encrypted data, contained in the input Buffer, to the output Buffer.
SSLDecoderTransformer() - Constructor for class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
SSLDecoderTransformer(MemoryManager) - Constructor for class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
SSLEncoderTransformer - Class in org.glassfish.grizzly.ssl
Transformer, which encrypts plain data, contained in the input Buffer, into SSL/TLS data and puts the result to the output Buffer.
SSLEncoderTransformer() - Constructor for class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
SSLEncoderTransformer(MemoryManager) - Constructor for class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
SSLEngineConfigurator - Class in org.glassfish.grizzly.ssl
Utility class, which helps to configure SSLEngine.
SSLEngineConfigurator(SSLContext) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContext.
SSLEngineConfigurator(SSLContext, boolean, boolean, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContext, using passed client mode, need/want client auth parameters.
SSLEngineConfigurator(SSLContextConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContextConfigurator.
SSLEngineConfigurator(SSLContextConfigurator, boolean, boolean, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
Create SSL Engine configuration basing on passed SSLContextConfigurator.
SSLEngineConfigurator(SSLEngineConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLEngineConfigurator() - Constructor for class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
SSLFilter - Class in org.glassfish.grizzly.ssl
SSL Filter to operate with SSL encrypted data.
SSLFilter() - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
 
SSLFilter(SSLEngineConfigurator, SSLEngineConfigurator) - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLFilter(SSLEngineConfigurator, SSLEngineConfigurator, boolean) - Constructor for class org.glassfish.grizzly.ssl.SSLFilter
Build SSLFilter with the given SSLEngineConfigurator.
SSLStreamReader - Class in org.glassfish.grizzly.ssl
SSL aware StreamReader implementation, which work like a wrapper over existing StreamReader.
SSLStreamReader(StreamReader) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamReader
 
SSLStreamWriter - Class in org.glassfish.grizzly.ssl
SSL aware StreamWriter implementation, which work like a wrapper over existing StreamWriter.
SSLStreamWriter(StreamWriter) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter
 
SSLStreamWriter.HandshakeCompletionHandler - Class in org.glassfish.grizzly.ssl
 
SSLStreamWriter.HandshakeCompletionHandler(FutureImpl<SSLEngine>, CompletionHandler<SSLEngine>, SSLEngine) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter.HandshakeCompletionHandler
 
SSLStreamWriter.SSLHandshakeCondition - Class in org.glassfish.grizzly.ssl
 
SSLStreamWriter.SSLHandshakeCondition(StreamReader, StreamWriter, SSLEngineConfigurator, SSLEngine, SSLStreamWriter.HandshakeCompletionHandler) - Constructor for class org.glassfish.grizzly.ssl.SSLStreamWriter.SSLHandshakeCondition
 
SSLSupport - Interface in org.glassfish.grizzly.ssl
SSLSupport Interface for SSL-specific functions
SSLSupport.CipherData - Class in org.glassfish.grizzly.ssl
Simple data class that represents the cipher being used, along with the corresponding effective key size.
SSLSupport.CipherData(String, int) - Constructor for class org.glassfish.grizzly.ssl.SSLSupport.CipherData
 
SSLSupportImpl - Class in org.glassfish.grizzly.ssl
 
SSLSupportImpl(Connection) - Constructor for class org.glassfish.grizzly.ssl.SSLSupportImpl
 
SSLUtils - Class in org.glassfish.grizzly.ssl
Utility class, which implements the set of useful SSL related operations.
SSLUtils() - Constructor for class org.glassfish.grizzly.ssl.SSLUtils
 
StandaloneProcessor - Class in org.glassfish.grizzly
Processor, which is not interested in processing I/O events.
StandaloneProcessor() - Constructor for class org.glassfish.grizzly.StandaloneProcessor
 
StandaloneProcessorSelector - Class in org.glassfish.grizzly
ProcessorSelector, which doesn't add any Processor to process occurred IOEvent.
StandaloneProcessorSelector() - Constructor for class org.glassfish.grizzly.StandaloneProcessorSelector
 
start - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
start() - Method in class org.glassfish.grizzly.http.server.HttpHandler
Called when the HttpHandler's container is started by invoking HttpServer.start().
start() - Method in class org.glassfish.grizzly.http.server.HttpHandlerChain
 
start() - Method in class org.glassfish.grizzly.http.server.HttpServer
Starts the HttpServer.
start() - Method in class org.glassfish.grizzly.http.server.NetworkListener
Starts the listener.
start() - Method in class org.glassfish.grizzly.nio.NIOTransport
Start TCPNIOTransport.
start() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
start() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
start() - Method in interface org.glassfish.grizzly.Transport
Starts the transport
start() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
start(String, int) - Method in interface org.glassfish.tyrus.spi.ServerContainer
Starts the server.
startSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
startsWith(Buffer, int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.BufferChunk
 
startsWith(String) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns true if the message bytes starts with the specified string.
startsWith(String, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns true if the message bytes starts with the specified string.
startsWith(byte[]) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
startsWith(byte[], int, int, byte[]) - Static method in class org.glassfish.grizzly.http.util.ByteChunk
 
startsWith(String) - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns true if the message bytes starts with the specified string.
startsWith(String, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns true if the DataChunk starts with the specified string.
startsWith(String) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns true if the message bytes starts with the specified string.
startsWithIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
startsWithIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
Returns true if the message bytes starts with the specified string.
startsWithIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
Returns true if the message bytes starts with the specified string.
startsWithIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
Returns true if the DataChunk starts with the specified string.
startsWithIgnoreCase(String, int) - Method in class org.glassfish.grizzly.http.util.MessageBytes
Returns true if the message bytes starts with the specified string.
startWorker(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
must hold statelock while calling this method.
startWorker(AbstractThreadPool.Worker) - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
state - Variable in class org.glassfish.grizzly.AbstractTransport
Transport state controller
state - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Get the current processing task state.
state - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
state31 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state311 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state311Distance - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state32 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state321 - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state321NumDirectBits - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state32PosSlot - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
state3Len - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
stateAttr - Variable in class org.glassfish.grizzly.AbstractTransformer
 
stateful() - Static method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
StateHolder<E> - Class in org.glassfish.grizzly.utils
Class, which holds the state.
StateHolder() - Constructor for class org.glassfish.grizzly.utils.StateHolder
Constructs StateHolder.
StateHolder(E) - Constructor for class org.glassfish.grizzly.utils.StateHolder
Constructs StateHolder.
StateHolder.ConditionElement<E> - Class in org.glassfish.grizzly.utils
 
StateHolder.ConditionElement(Condition, FutureImpl<E>, CompletionHandler<E>) - Constructor for class org.glassfish.grizzly.utils.StateHolder.ConditionElement
 
stateInit() - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateIsCharState(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateless() - Static method in class org.glassfish.grizzly.filterchain.FilterChainBuilder
 
stateLock - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
stateUpdateChar(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateMatch(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateRep(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
stateUpdateShortRep(int) - Static method in class org.glassfish.grizzly.compression.lzma.impl.Base
 
staticBitIndex - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticHolder(T) - Static method in class org.glassfish.grizzly.utils.Holder
 
StaticHttpHandler - Class in org.glassfish.grizzly.http.server
HttpHandler, which processes requests to a static resources.
StaticHttpHandler() - Constructor for class org.glassfish.grizzly.http.server.StaticHttpHandler
Create HttpHandler, which, by default, will handle requests to the static resources located in the current directory.
StaticHttpHandler(String...) - Constructor for class org.glassfish.grizzly.http.server.StaticHttpHandler
Create a new instance which will look for static pages located under the docRoot.
StaticHttpHandler(Set<String>) - Constructor for class org.glassfish.grizzly.http.server.StaticHttpHandler
Create a new instance which will look for static pages located under the docRoot.
StaticHttpHandlerBase - Class in org.glassfish.grizzly.http.server
The basic class for HttpHandler implementations, which processes requests to a static resources.
StaticHttpHandlerBase() - Constructor for class org.glassfish.grizzly.http.server.StaticHttpHandlerBase
 
staticIntHolder(int) - Static method in class org.glassfish.grizzly.utils.Holder
 
staticM - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticReverseDecodeMethodState - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
staticSymbol - Variable in class org.glassfish.grizzly.compression.lzma.LZMADecoder.LZMAInputState
 
status - Variable in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
 
status(int) - Method in class org.glassfish.grizzly.http.HttpResponsePacket.Builder
Sets the status code for this response.
STATUS_CODE_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The request attribute under which we forward an HTTP status code (as an object of type Integer) to an error page.
statusMatches(int) - Method in class org.glassfish.grizzly.http.util.HttpStatus
 
stop() - Method in class org.glassfish.grizzly.AbstractTransport
Deprecated.
stop() - Method in class org.glassfish.grizzly.http.server.HttpServer
Deprecated.
stop() - Method in class org.glassfish.grizzly.http.server.NetworkListener
stop() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
stop() - Method in interface org.glassfish.grizzly.threadpool.WorkerThread
 
stop() - Method in interface org.glassfish.grizzly.Transport
Deprecated.
stop() - Method in class org.glassfish.grizzly.utils.DelayedExecutor
 
stop() - Method in interface org.glassfish.tyrus.spi.ServerContainer
Stops the server.
stopSelectorRunners() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
store - Variable in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
Backing store for the [key, multi-value] pairs.
strategy - Variable in class org.glassfish.grizzly.AbstractTransport
Transport strategy
Stream - Interface in org.glassfish.grizzly.streams
Common interface for Stream readers and writers.
stream(boolean, byte[], int, int) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
stream(boolean, String) - Method in class org.glassfish.tyrus.core.ProtocolHandler
 
StreamDecodeCondition<E> - Class in org.glassfish.grizzly.streams
 
StreamDecodeCondition(StreamReader, Transformer<Stream, E>, ResultAware<E>) - Constructor for class org.glassfish.grizzly.streams.StreamDecodeCondition
 
StreamInput - Class in org.glassfish.grizzly.streams
 
StreamInput(StreamReader) - Constructor for class org.glassfish.grizzly.streams.StreamInput
 
StreamOutput - Class in org.glassfish.grizzly.streams
 
StreamOutput(StreamWriter) - Constructor for class org.glassfish.grizzly.streams.StreamOutput
 
StreamReader - Interface in org.glassfish.grizzly.streams
Interface that defines methods for reading primitive types and arrays of primitive types from a stream.
StreamWriter - Interface in org.glassfish.grizzly.streams
Write the primitive Java types and arrays of primitives to some data sink.
StrictUtf8 - Class in org.glassfish.tyrus.core
 
StrictUtf8() - Constructor for class org.glassfish.tyrus.core.StrictUtf8
 
StrictUtf8.Parser - Class in org.glassfish.tyrus.core
Surrogate parsing support.
StrictUtf8.Parser() - Constructor for class org.glassfish.tyrus.core.StrictUtf8.Parser
 
strictVersionOneCompliant - Variable in class org.glassfish.grizzly.http.CookiesBuilder.AbstractCookiesBuilder
 
StringCache - Class in org.glassfish.grizzly.http.util
This class implements a String cache for ByteChunk and CharChunk.
StringCache() - Constructor for class org.glassfish.grizzly.http.util.StringCache
 
StringCache.ByteEntry - Class in org.glassfish.grizzly.http.util
 
StringCache.ByteEntry() - Constructor for class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
StringCache.CharEntry - Class in org.glassfish.grizzly.http.util
 
StringCache.CharEntry() - Constructor for class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
StringDecoder - Class in org.glassfish.grizzly.utils
String decoder, which decodes Buffer to String
StringDecoder() - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(String) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(Charset) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringDecoder(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringDecoder
 
StringEncoder - Class in org.glassfish.grizzly.utils
String decoder, which decodes Buffer to String
StringEncoder() - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(String) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(Charset) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringEncoder(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringEncoder
 
StringFilter - Class in org.glassfish.grizzly.utils
StringFilter implementation, which performs Buffer <-> String transformation.
StringFilter() - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
StringFilter(Charset) - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
StringFilter(Charset, String) - Constructor for class org.glassfish.grizzly.utils.StringFilter
 
StringManager - Class in org.glassfish.grizzly.http.util
An internationalization / localization helper class which reduces the bother of handling ResourceBundles and takes care of the common cases of message formatting which otherwise require the creation of Object arrays and such.
StringParser - Class in org.glassfish.grizzly.http.server.util
Utility class for string parsing that is higher performance than StringParser for simple delimited text cases.
StringParser() - Constructor for class org.glassfish.grizzly.http.server.util.StringParser
Construct a string parser with no preset string to be parsed.
StringParser(String) - Constructor for class org.glassfish.grizzly.http.server.util.StringParser
Construct a string parser that is initialized to parse the specified string.
stringTerminateBytes - Variable in class org.glassfish.grizzly.utils.StringDecoder
 
stringTerminator - Variable in class org.glassfish.grizzly.utils.StringEncoder
 
subHeapSize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
subject - Variable in class org.glassfish.grizzly.http.server.Request
The Subject associated with the current AccessControllerContext
SUBJECT_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The subject under which the AccessControlContext is running.
subList(int, int) - Method in class org.glassfish.grizzly.ChainProcessorSelector
subList(int, int) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
subMappedMemorySize(long) - Method in class org.glassfish.grizzly.http.server.filecache.FileCache
 
subprotocols(List<String>) - Method in class javax.websocket.server.ServerEndpointConfig.Builder
Sets the subprotocols to use in the configuration.
subState - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.HeaderParsingState
 
substract() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
substract(ByteChunk) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
substract(byte[], int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
substract() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
substract(CharChunk) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
substract(char[], int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
suspend() - Method in class org.glassfish.grizzly.Context
Notify Context its processing will be suspended in the current thread.
suspend() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Suspend processing of the current task
suspend() - Method in class org.glassfish.grizzly.http.server.Response
Suspend the Response.
suspend(long, TimeUnit) - Method in class org.glassfish.grizzly.http.server.Response
Deprecated.
timeout parameters don't make any sense without CompletionHandler
suspend(long, TimeUnit, CompletionHandler<Response>) - Method in class org.glassfish.grizzly.http.server.Response
Suspend the Response.
suspend(long, TimeUnit, CompletionHandler<Response>, TimeoutHandler) - Method in class org.glassfish.grizzly.http.server.Response
Suspend the Response.
suspend() - Method in class org.glassfish.grizzly.http.server.SuspendStatus
 
SuspendContext - Interface in org.glassfish.grizzly.http.server
Interface represents a context of the suspended Response.
SuspendStatus - Class in org.glassfish.grizzly.http.server
The request/response suspend status bound to a specific thread.
SWITCHING_PROTOCOLS_101 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
switchToNewSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
SyncThreadPool - Class in org.glassfish.grizzly.threadpool
ExecutorService implementation, which function the similar way as former Grizzly 1.x Pipeline based thread pools.
SyncThreadPool(ThreadPoolConfig) - Constructor for class org.glassfish.grizzly.threadpool.SyncThreadPool
 
SyncThreadPool.SyncThreadWorker - Class in org.glassfish.grizzly.threadpool
 
SyncThreadPool.SyncThreadWorker(boolean) - Constructor for class org.glassfish.grizzly.threadpool.SyncThreadPool.SyncThreadWorker
 

T

t - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
t - Variable in class org.glassfish.tyrus.core.ReflectionHelper.ClassTypePair
The type of the class.
t - Variable in class org.glassfish.tyrus.core.ReflectionHelper.TypeClassPair
 
T_BYTES - Static variable in class org.glassfish.grizzly.http.util.MessageBytes
getType() is T_STR if the the object used to create the MessageBytes was a byte[]
T_CHARS - Static variable in class org.glassfish.grizzly.http.util.MessageBytes
getType() is T_STR if the the object used to create the MessageBytes was a char[]
T_NULL - Static variable in class org.glassfish.grizzly.http.util.MessageBytes
 
T_STR - Static variable in class org.glassfish.grizzly.http.util.MessageBytes
getType() is T_STR if the the object used to create the MessageBytes was a String
take(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.ThreadCache.ObjectCache
Take the cached object with the given type index from cache.
take() - Method in class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
Take (poll) the object from cache.
take() - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
 
takeBuffer() - Method in class org.glassfish.grizzly.streams.BufferedInput
 
takeBuffer() - Method in interface org.glassfish.grizzly.streams.Input
Takes the Input's Buffer.
takeBuffer() - Method in class org.glassfish.grizzly.streams.StreamInput
 
takeBufferWindow() - Method in class org.glassfish.grizzly.streams.AbstractStreamReader
takeBufferWindow() - Method in interface org.glassfish.grizzly.streams.StreamReader
 
takeFromCache(ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Take the cached object with the given type index from cache.
takeFromCache(Thread, ThreadCache.CachedTypeIndex<E>) - Static method in class org.glassfish.grizzly.ThreadCache
Take the cached object with the given type index from cache.
takeFromCache(ThreadCache.CachedTypeIndex<E>) - Method in class org.glassfish.grizzly.threadpool.DefaultWorkerThread
Take the cached object with the given type index from cache.
TaskProcessor - Class in org.glassfish.tyrus.container.grizzly.client
Class responsible for processing TaskProcessor.Task queues.
TaskProcessor() - Constructor for class org.glassfish.tyrus.container.grizzly.client.TaskProcessor
 
TaskProcessor.Condition - Interface in org.glassfish.tyrus.container.grizzly.client
TaskProcessor.Task - Class in org.glassfish.tyrus.container.grizzly.client
Generic task representation.
TaskProcessor.Task() - Constructor for class org.glassfish.tyrus.container.grizzly.client.TaskProcessor.Task
 
TaskQueue<E extends AsyncQueueRecord> - Class in org.glassfish.grizzly.asyncqueue
Class represents common implementation of asynchronous processing queue.
TaskQueue(TaskQueue.MutableMaxQueueSize) - Constructor for class org.glassfish.grizzly.asyncqueue.TaskQueue
 
TaskQueue.MutableMaxQueueSize - Interface in org.glassfish.grizzly.asyncqueue
 
TCPNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio.transport
The TCP transport AsyncQueueReader implementation, based on the Java NIO
TCPNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueReader
 
TCPNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio.transport
The TCP transport AsyncQueueWriter implementation, based on the Java NIO
TCPNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
TCPNIOBindingHandler - Class in org.glassfish.grizzly.nio.transport
This class may be used to apply a custom Processor and/or ProcessorSelector atomically within a bind operation - not something that can normally be done using the TCPNIOTransport alone.
TCPNIOBindingHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOBindingHandler.Builder() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler.Builder
 
TCPNIOConnection - Class in org.glassfish.grizzly.nio.transport
Connection implementation for the TCPNIOTransport
TCPNIOConnection(TCPNIOTransport, SelectableChannel) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
TCPNIOConnection.ConnectResultHandler - Interface in org.glassfish.grizzly.nio.transport
This interface implementations can be used to be notified about the TCPNIOConnection connect state.
TCPNIOConnectorHandler - Class in org.glassfish.grizzly.nio.transport
TCP NIO transport client side ConnectorHandler implementation
TCPNIOConnectorHandler(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
TCPNIOConnectorHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOConnectorHandler.Builder() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler.Builder
 
TCPNIOServerConnection - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOServerConnection(TCPNIOTransport, ServerSocketChannel) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler(FutureImpl<Connection>) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOServerConnection.RegisterAcceptedChannelCompletionHandler
 
TCPNIOTemporarySelectorReader - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOTemporarySelectorReader(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorReader
 
TCPNIOTemporarySelectorWriter - Class in org.glassfish.grizzly.nio.transport
 
TCPNIOTemporarySelectorWriter(TCPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorWriter
 
TCPNIOTransport - Class in org.glassfish.grizzly.nio.transport
TCP Transport NIO implementation
TCPNIOTransport() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
TCPNIOTransportBuilder - Class in org.glassfish.grizzly.nio.transport
NIOTransportBuilder implementation for TCP.
TCPNIOTransportBuilder(Class<? extends TCPNIOTransport>) - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
TCPNIOTransportFilter - Class in org.glassfish.grizzly.nio.transport
The TCPNIOTransport's transport Filter implementation
TCPNIOUtils - Class in org.glassfish.grizzly.nio.transport
TCP NIO Transport utils
TCPNIOUtils() - Constructor for class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
tcpNoDelay - Variable in class org.glassfish.grizzly.nio.transport.TCPNIOTransportBuilder
 
TEMPORARY_REDIRECT_307 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
temporarySelectorIO - Variable in class org.glassfish.grizzly.nio.NIOTransport
 
TemporarySelectorIO - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorIO(Reader<SocketAddress>, Writer<SocketAddress>) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
TemporarySelectorIO(Reader<SocketAddress>, Writer<SocketAddress>, TemporarySelectorPool) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorIO
 
TemporarySelectorPool - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorPool(SelectorProvider) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
TemporarySelectorPool(SelectorProvider, int) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorPool
 
TemporarySelectorReader - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorReader(TemporarySelectorsEnabledTransport) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
TemporarySelectorsEnabledTransport - Interface in org.glassfish.grizzly.nio.tmpselectors
Common interface for Transports, which will use temporary selectors technics
TemporarySelectorWriter - Class in org.glassfish.grizzly.nio.tmpselectors
 
TemporarySelectorWriter(TemporarySelectorsEnabledTransport) - Constructor for class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
terminate() - Method in class org.glassfish.grizzly.http.io.InputBuffer
Invoke ReadHandler.onError(Throwable) (assuming a ReadHandler is available) } passing a {#link CancellationException} if the current Connection is open, or a {#link EOFException} if the connection was unexpectedly closed.
TEXT_MESSAGE_HANDLER_NOT_FOUND(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Text message handler not found.
TEXT_MESSAGE_OUT_OF_ORDER(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Text message received out of order.
TextFrame - Class in org.glassfish.tyrus.core.frame
Text frame representation.
TextFrame(Frame, ByteBuffer) - Constructor for class org.glassfish.tyrus.core.frame.TextFrame
Constructor.
TextFrame(Frame, ByteBuffer, boolean) - Constructor for class org.glassfish.tyrus.core.frame.TextFrame
Constructor.
TextFrame(String, boolean, boolean) - Constructor for class org.glassfish.tyrus.core.frame.TextFrame
Constructor.
ThreadCache - Class in org.glassfish.grizzly
 
ThreadCache() - Constructor for class org.glassfish.grizzly.ThreadCache
 
ThreadCache.CachedTypeIndex<E> - Class in org.glassfish.grizzly
 
ThreadCache.CachedTypeIndex(int, String, Class<E>, int) - Constructor for class org.glassfish.grizzly.ThreadCache.CachedTypeIndex
 
ThreadCache.ObjectCache - Class in org.glassfish.grizzly
 
ThreadCache.ObjectCache() - Constructor for class org.glassfish.grizzly.ThreadCache.ObjectCache
 
ThreadCache.ObjectCacheElement - Class in org.glassfish.grizzly
 
ThreadCache.ObjectCacheElement(int) - Constructor for class org.glassfish.grizzly.ThreadCache.ObjectCacheElement
 
threadFactory - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
ThreadLocalPool<E> - Interface in org.glassfish.grizzly.memory
TODO Documentation
ThreadLocalPoolProvider - Interface in org.glassfish.grizzly.memory
This interface may be implemented by custom MemoryManager implementations in order to provide per-thread memory management.
ThreadPoolConfig - Class in org.glassfish.grizzly.threadpool
Grizzly thread-pool configuration, which might be used to create and initialize a thread-pool via GrizzlyExecutorService.createInstance(org.glassfish.grizzly.threadpool.ThreadPoolConfig).
threadPoolMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Thread pool probes
threadPoolMonitoringConfig - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
Thread pool probes
ThreadPoolProbe - Interface in org.glassfish.grizzly.threadpool
Monitoring probe providing callbacks that may be invoked by Grizzly AbstractThreadPool implementations.
ThreadPoolProbe.Adapter - Class in org.glassfish.grizzly.threadpool
ThreadPoolProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
ThreadPoolProbe.Adapter() - Constructor for class org.glassfish.grizzly.threadpool.ThreadPoolProbe.Adapter
 
Threads - Class in org.glassfish.grizzly.threadpool
Set of Thread utilities.
Threads() - Constructor for class org.glassfish.grizzly.threadpool.Threads
 
TimeoutHandler - Interface in org.glassfish.grizzly.http.server
Handler, which processes suspended Response timeout and is able to either confirm it or reset.
timeoutMillis - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
TimeStamp - Class in org.glassfish.grizzly.http.util
Main tool for object expiry.
TimeStamp() - Constructor for class org.glassfish.grizzly.http.util.TimeStamp
 
tmpMapperDC - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
toAbsolute(String, boolean) - Method in class org.glassfish.grizzly.http.server.Response
Convert (if necessary) and return the absolute URL that represents the resource referenced by this possibly relative URL.
toAdaptedCompletionHandler(FutureImpl<A>, GenericAdapter<B, A>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl.
toAdaptedCompletionHandler(FutureImpl<A>, CompletionHandler<A>, GenericAdapter<B, A>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl and CompletionHandler.
toArray() - Method in class org.glassfish.grizzly.ChainProcessorSelector
toArray(T[]) - Method in class org.glassfish.grizzly.ChainProcessorSelector
toArray() - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
toArray(T[]) - Method in class org.glassfish.grizzly.filterchain.ListFacadeFilterChain
toArray() - Method in class org.glassfish.grizzly.utils.ArraySet
toArray(K[]) - Method in class org.glassfish.grizzly.utils.ArraySet
toArray() - Method in class org.glassfish.grizzly.utils.ServiceFinder
Returns discovered objects all at once.
toArray() - Method in class org.glassfish.tyrus.core.ServiceFinder
Returns discovered objects all at once.
toArray(long) - Static method in class org.glassfish.tyrus.core.Utils
Convert long to byte[].
toBufferArray() - Method in interface org.glassfish.grizzly.Buffer
Returns a new BufferArray instance with this Buffer added as an element to the BufferArray.
toBufferArray(BufferArray) - Method in interface org.glassfish.grizzly.Buffer
Returns the specified BufferArray after adding this Buffer.
toBufferArray(int, int) - Method in interface org.glassfish.grizzly.Buffer
Updates this Buffer's position and limit and adds it to a new BufferArray instance.
toBufferArray(BufferArray, int, int) - Method in interface org.glassfish.grizzly.Buffer
Updates this Buffer's position and limit and adds it to the specified BufferArray.
toBufferArray() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toBufferArray() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Returns a new BufferArray instance with this Buffer added as an element to the BufferArray.
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Updates this Buffer's position and limit and adds it to a new BufferArray instance.
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Returns the specified BufferArray after adding this Buffer.
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Updates this Buffer's position and limit and adds it to the specified BufferArray.
toBufferArray() - Method in class org.glassfish.grizzly.memory.HeapBuffer
Returns a new BufferArray instance with this Buffer added as an element to the BufferArray.
toBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Updates this Buffer's position and limit and adds it to a new BufferArray instance.
toBufferArray(BufferArray) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Returns the specified BufferArray after adding this Buffer.
toBufferArray(BufferArray, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Updates this Buffer's position and limit and adds it to the specified BufferArray.
toByteArray() - Method in enum org.glassfish.grizzly.http.util.Header
Returns the US-ASCII encoded byte representation of this Header.
toByteBuffer() - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer.
toByteBuffer(int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer.
toByteBuffer() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBuffer() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer.
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer.
toByteBuffer() - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer.
toByteBuffer(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer.
toByteBuffer0(int, int, boolean) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toByteBufferArray() - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and adds the result to the provided ByteBufferArray.
toByteBufferArray(int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray, int, int) - Method in interface org.glassfish.grizzly.Buffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and adds the result to the provided ByteBufferArray.
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and adds the result to the provided ByteBufferArray.
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and adds the result to the provided ByteBufferArray.
toByteBufferArray() - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and returns a ByteBufferArray containing the converted ByteBuffer.
toByteBufferArray(ByteBufferArray) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer() and adds the result to the provided ByteBufferArray.
toByteBufferArray(ByteBufferArray, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
Converts this Buffer to a ByteBuffer per Buffer.toByteBuffer(int, int) and adds the result to the provided ByteBufferArray.
toBytes() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Unimplemented yet.
toChars(Charset) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
toChars() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Convert to char[] and fill the CharChunk.
toCheckedByteArray(CharSequence) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
Converts the a CharSequence to a byte array, eliminating all the unprintable US-ASCII symbols by replacing them with spaces (' ').
toCheckedByteArray(CharSequence, byte[], int) - Static method in class org.glassfish.grizzly.http.util.HttpCodecUtils
Serializes the passed CharSequence into a passed byte array starting from a given offset.
toClassArray() - Method in class org.glassfish.tyrus.core.ServiceFinder
Returns discovered classes all at once.
toCompletionHandler(FutureImpl<R>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl.
toCompletionHandler(FutureImpl<R>, CompletionHandler<R>) - Static method in class org.glassfish.grizzly.utils.Futures
Creates CompletionHandler, which may serve as a bridge for passed FutureImpl and CompletionHandler objects.
toEncoded(String, String) - Method in class org.glassfish.grizzly.http.server.Response
Return the specified URL with the specified session identifier suitably encoded.
toImmutable() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
toLong(byte[], int, int) - Static method in class org.glassfish.tyrus.core.Utils
Convert byte[] to long.
toLower(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns the lower case equivalent of the specified ASCII character.
toLower(byte[]) - Static method in class org.glassfish.grizzly.http.util.Ascii
Converts passed bytes (representing ASCII characters) to the lower case equivalent.
toProcessorResult() - Method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
 
toString() - Method in class javax.websocket.CloseReason
Converts the CloseReason to a debug-friendly string.
toString() - Method in class org.glassfish.grizzly.attributes.Attribute
 
toString() - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
toString() - Method in class org.glassfish.grizzly.http.Cookie
 
toString() - Method in class org.glassfish.grizzly.http.Cookies
EXPENSIVE!!! only for debugging.
toString() - Method in class org.glassfish.grizzly.http.HttpRequestPacket
toString() - Method in class org.glassfish.grizzly.http.HttpResponsePacket
toString() - Method in class org.glassfish.grizzly.http.LazyCookieState
 
toString() - Method in class org.glassfish.grizzly.http.Method
 
toString() - Method in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
toString() - Method in class org.glassfish.grizzly.http.server.GrizzlyPrincipal
Return a String representation of this object, which exposes only information that should be public.
toString() - Method in class org.glassfish.grizzly.http.server.NetworkListener
 
toString() - Method in class org.glassfish.grizzly.http.server.util.MappingData
 
toString() - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
toString(Charset) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
toString(int, int) - Method in class org.glassfish.grizzly.http.util.BufferChunk
 
toString() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
toString(int, int) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
toString(Charset) - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
toString() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
toString(int, int) - Method in class org.glassfish.grizzly.http.util.CharChunk
 
toString(int, int) - Method in interface org.glassfish.grizzly.http.util.Chunk
 
toString() - Method in class org.glassfish.grizzly.http.util.ContentType
 
toString() - Method in class org.glassfish.grizzly.http.util.DataChunk
 
toString(Charset) - Method in class org.glassfish.grizzly.http.util.DataChunk
 
toString(int, int) - Method in class org.glassfish.grizzly.http.util.DataChunk
toString() - Method in enum org.glassfish.grizzly.http.util.Header
Returns the name of the header properly hyphenated if necessary.
toString() - Method in class org.glassfish.grizzly.http.util.HeaderValue
 
toString() - Method in class org.glassfish.grizzly.http.util.MessageBytes
Compute the string value
toString() - Method in class org.glassfish.grizzly.http.util.MimeHeaders
EXPENSIVE!!! only for debugging.
toString() - Method in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
toString() - Method in class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
toString(ByteChunk) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
toString(CharChunk) - Static method in class org.glassfish.grizzly.http.util.StringCache
 
toString() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toString() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toString() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toString() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnection
 
toString() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
toString() - Method in class org.glassfish.grizzly.PortRange
 
toString() - Method in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
 
toString() - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
toString() - Method in class org.glassfish.grizzly.threadpool.SyncThreadPool
 
toString() - Method in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
toString() - Method in class org.glassfish.grizzly.TransformationResult
 
toString() - Method in class org.glassfish.grizzly.utils.DebugPoint
 
toString() - Method in class org.glassfish.grizzly.utils.Holder
 
toString() - Method in class org.glassfish.grizzly.utils.JdkVersion
 
toString() - Method in class org.glassfish.grizzly.utils.Pair
 
toString() - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
toString() - Method in enum org.glassfish.tyrus.core.cluster.ClusterSession.DistributedMapKey
 
toString() - Method in class org.glassfish.tyrus.core.coder.CoderWrapper
 
toString() - Method in class org.glassfish.tyrus.core.frame.Frame
 
toString() - Method in class org.glassfish.tyrus.core.frame.TextFrame
 
toString() - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
 
toString() - Method in class org.glassfish.tyrus.core.TyrusExtension
 
toString() - Method in class org.glassfish.tyrus.core.TyrusExtension.TyrusParameter
 
toString() - Method in class org.glassfish.tyrus.core.TyrusRemoteEndpoint
 
toString() - Method in class org.glassfish.tyrus.core.TyrusSession
 
toString() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
toString() - Method in class org.glassfish.tyrus.core.uri.internal.PatternWithGroups
 
toString() - Method in class org.glassfish.tyrus.core.uri.internal.UriTemplate
 
toString() - Method in class org.glassfish.tyrus.core.uri.Match
 
toString(byte[]) - Static method in class org.glassfish.tyrus.core.Utils
 
toString(byte[], int, int) - Static method in class org.glassfish.tyrus.core.Utils
 
toString() - Method in enum org.glassfish.tyrus.core.Version
 
toStringContent() - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer content as String, using default Charset
toStringContent(Charset) - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer content as String
toStringContent(Charset, int, int) - Method in interface org.glassfish.grizzly.Buffer
Returns Buffer's chunk content as String
toStringContent(ByteBuffer, Charset, int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
 
toStringContent() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
toStringContent() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
toStringContent() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toStringContent(Charset) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
toStringContent(Charset, int, int) - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
ToStringEncoder - Class in org.glassfish.tyrus.core.coder
Fall-back encoder - encoders any object to string using Object.toString() method.
ToStringEncoder() - Constructor for class org.glassfish.tyrus.core.coder.ToStringEncoder
 
toStringInternal() - Method in class org.glassfish.grizzly.http.util.ByteChunk
 
toStringInternal() - Method in class org.glassfish.grizzly.http.util.CharChunk
 
touch(long) - Method in class org.glassfish.grizzly.http.util.TimeStamp
Access notification.
toUpper(int) - Static method in class org.glassfish.grizzly.http.util.Ascii
Returns the upper case equivalent of the specified ASCII character.
toUpper(byte[]) - Static method in class org.glassfish.grizzly.http.util.Ascii
Converts passed bytes (representing ASCII characters) to the upper case equivalent.
TRACE - Static variable in class org.glassfish.grizzly.http.Method
 
trailerHeaders - Variable in class org.glassfish.grizzly.http.HttpCodecFilter.ContentParsingState
 
transactionExpirationTime - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool.Worker
 
transactionMonitor - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
transactionTimeoutMillis - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
transactionTimeoutMillis - Variable in class org.glassfish.grizzly.threadpool.ThreadPoolConfig
 
transfer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
transfer(E) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Inserts the specified element into this queue, waiting if necessary for space to become available and the element to be dequeued by a consumer invoking take or poll.
TRANSFERENCODING - Static variable in class org.glassfish.grizzly.http.server.Constants
 
TransferEncoding - Interface in org.glassfish.grizzly.http
Abstraction, which represents HTTP transfer-encoding.
TransferQueue<E> - Interface in org.glassfish.grizzly.utils
A BlockingQueue in which producers may wait for consumers to receive elements.
transform(AttributeStorage, K) - Method in class org.glassfish.grizzly.AbstractTransformer
 
transform(AttributeStorage, K) - Method in interface org.glassfish.grizzly.Transformer
Transforms an input data to some custom representation.
TransformationException - Exception in org.glassfish.grizzly
Describes the problem, occured during original message transformation.
TransformationException() - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(String) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(Throwable) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationException(String, Throwable) - Constructor for exception org.glassfish.grizzly.TransformationException
 
TransformationResult<I,O> - Class in org.glassfish.grizzly
Represents the result of message encoding/decoding.
TransformationResult() - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult(TransformationResult.Status, O, I) - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult(int, String) - Constructor for class org.glassfish.grizzly.TransformationResult
Creates error transformation result with specific code and description.
TransformationResult(TransformationResult.Status, O, I, int, String) - Constructor for class org.glassfish.grizzly.TransformationResult
 
TransformationResult.Status - Enum in org.glassfish.grizzly
 
transformer - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
transformer - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
Transformer<K,L> - Interface in org.glassfish.grizzly
Transformer interface, which knows how to transform the original data to some custom representation.
TransformerInput - Class in org.glassfish.grizzly.streams
 
TransformerInput(Transformer<Buffer, Buffer>, Input, Connection) - Constructor for class org.glassfish.grizzly.streams.TransformerInput
 
TransformerInput(Transformer<Buffer, Buffer>, Input, MemoryManager, AttributeStorage) - Constructor for class org.glassfish.grizzly.streams.TransformerInput
 
TransformerInput.TransformerCompletionHandler - Class in org.glassfish.grizzly.streams
 
TransformerInput.TransformerCompletionHandler() - Constructor for class org.glassfish.grizzly.streams.TransformerInput.TransformerCompletionHandler
 
TransformerInput.TransformerCondition - Class in org.glassfish.grizzly.streams
 
TransformerInput.TransformerCondition() - Constructor for class org.glassfish.grizzly.streams.TransformerInput.TransformerCondition
 
TransformerOutput - Class in org.glassfish.grizzly.streams
 
TransformerOutput(Transformer<Buffer, Buffer>, Output, Connection) - Constructor for class org.glassfish.grizzly.streams.TransformerOutput
 
TransformerOutput(Transformer<Buffer, Buffer>, Output, MemoryManager, AttributeStorage) - Constructor for class org.glassfish.grizzly.streams.TransformerOutput
 
TransformerStreamReader - Class in org.glassfish.grizzly.streams
 
TransformerStreamReader(StreamReader, Transformer<Buffer, Buffer>) - Constructor for class org.glassfish.grizzly.streams.TransformerStreamReader
 
TransformerStreamWriter - Class in org.glassfish.grizzly.streams
 
TransformerStreamWriter(StreamWriter, Transformer<Buffer, Buffer>) - Constructor for class org.glassfish.grizzly.streams.TransformerStreamWriter
 
transformImpl(AttributeStorage, K) - Method in class org.glassfish.grizzly.AbstractTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMADecoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.lzma.LZMAEncoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipDecoder
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.compression.zip.GZipEncoder
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLDecoderTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.ssl.SSLEncoderTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.ChunkingFilter.ChunkingTransformer
 
transformImpl(AttributeStorage, Buffer) - Method in class org.glassfish.grizzly.utils.StringDecoder
 
transformImpl(AttributeStorage, String) - Method in class org.glassfish.grizzly.utils.StringEncoder
 
transport - Variable in class org.glassfish.grizzly.AbstractBindingHandler
 
transport - Variable in class org.glassfish.grizzly.AbstractSocketConnectorHandler
 
transport - Variable in class org.glassfish.grizzly.DefaultProcessorSelector
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueReader
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
transport - Variable in class org.glassfish.grizzly.nio.AbstractNIOConnectionDistributor
 
transport - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
transport - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorReader
 
transport - Variable in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
transport(TCPNIOTransport) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler.Builder
 
transport(UDPNIOTransport) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler.Builder
 
Transport - Interface in org.glassfish.grizzly
Transport interface describes the transport unit used in Grizzly.
Transport.State - Enum in org.glassfish.grizzly
 
transportClass - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
TransportFilter - Class in org.glassfish.grizzly.filterchain
Transport Filter implementation, which should work with any Transport.
TransportFilter() - Constructor for class org.glassfish.grizzly.filterchain.TransportFilter
Create TransportFilter.
TransportFilter.FlushEvent - Class in org.glassfish.grizzly.filterchain
 
transportMonitoringConfig - Variable in class org.glassfish.grizzly.AbstractTransport
Transport probes
TransportProbe - Interface in org.glassfish.grizzly
Monitoring probe providing callbacks that may be invoked by Grizzly Transport implementations.
TransportProbe.Adapter - Class in org.glassfish.grizzly
TransportProbe adapter that provides no-op implementations for all interface methods allowing easy extension by the developer.
TransportProbe.Adapter() - Constructor for class org.glassfish.grizzly.TransportProbe.Adapter
 
trim() - Method in interface org.glassfish.grizzly.Buffer
Trim the buffer by reducing capacity to position, if possible.
trim() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
trim() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
trim() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
TRUST_FACTORY_MANAGER_ALGORITHM - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_FILE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_PASSWORD - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_PROVIDER - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
TRUST_STORE_TYPE - Static variable in class org.glassfish.grizzly.ssl.SSLContextConfigurator
 
tryDispose() - Method in interface org.glassfish.grizzly.Buffer
Try to dispose Buffer if it's allowed.
tryDispose() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
tryDispose() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
tryDispose() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
tryTransfer(E) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in class org.glassfish.grizzly.utils.LinkedTransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryTransfer(E) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Transfers the specified element if there exists a consumer already waiting to receive it, otherwise returning false without enqueuing the element.
tryTransfer(E, long, TimeUnit) - Method in interface org.glassfish.grizzly.utils.TransferQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available and the element to be dequeued by a consumer invoking take or poll.
type() - Method in interface org.glassfish.grizzly.filterchain.FilterChainEvent
 
type() - Method in interface org.glassfish.grizzly.filterchain.NextAction
Get NextAction type
TYPE - Static variable in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
type() - Method in class org.glassfish.grizzly.filterchain.TransportFilter.FlushEvent
 
type - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 
type() - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter.CertificateEvent
 
TyrusClientEngine - Class in org.glassfish.tyrus.client
Tyrus ClientEngine implementaion.
TyrusClientEngine.ClientHandshakeListener - Interface in org.glassfish.tyrus.client
Called when response is received from the server.
TyrusEndpointWrapper - Class in org.glassfish.tyrus.core
Wraps the registered application class.
TyrusEndpointWrapper(Class<? extends Endpoint>, EndpointConfig, ComponentProviderService, WebSocketContainer, String, ServerEndpointConfig.Configurator) - Constructor for class org.glassfish.tyrus.core.TyrusEndpointWrapper
Create TyrusEndpointWrapper for class that extends Endpoint.
TyrusEndpointWrapper(Endpoint, EndpointConfig, ComponentProviderService, WebSocketContainer, String, ServerEndpointConfig.Configurator, TyrusEndpointWrapper.OnCloseListener, ClusterContext) - Constructor for class org.glassfish.tyrus.core.TyrusEndpointWrapper
Create TyrusEndpointWrapper for Endpoint instance or AnnotatedEndpoint instance.
TyrusEndpointWrapper.OnCloseListener - Interface in org.glassfish.tyrus.core
Close listener.
TyrusExtension - Class in org.glassfish.tyrus.core
WebSocket Extension implementation.
TyrusExtension(String) - Constructor for class org.glassfish.tyrus.core.TyrusExtension
Create Extension with specific name.
TyrusExtension(String, List<Extension.Parameter>) - Constructor for class org.glassfish.tyrus.core.TyrusExtension
Create Extension with name and parameters.
TyrusExtension.TyrusParameter - Class in org.glassfish.tyrus.core
WebSocket Parameter implementation.
TyrusExtension.TyrusParameter(String, String) - Constructor for class org.glassfish.tyrus.core.TyrusExtension.TyrusParameter
Create Parameter with name and value.
TyrusFrame - Class in org.glassfish.tyrus.core.frame
Frame representation used in Tyrus runtime.
TyrusFrame(Frame) - Constructor for class org.glassfish.tyrus.core.frame.TyrusFrame
 
TyrusFuture<T> - Class in org.glassfish.tyrus.core
Simple Future implementation.
TyrusFuture() - Constructor for class org.glassfish.tyrus.core.TyrusFuture
 
TyrusRemoteEndpoint - Class in org.glassfish.tyrus.core
Wraps the RemoteEndpoint and represents the other side of the websocket connection.
TyrusSession - Class in org.glassfish.tyrus.core
Implementation of the Session.
TyrusUpgradeResponse - Class in org.glassfish.tyrus.core
HTTP response representation.
TyrusUpgradeResponse() - Constructor for class org.glassfish.tyrus.core.TyrusUpgradeResponse
 
TyrusWebSocket - Class in org.glassfish.tyrus.core
Tyrus representation of web socket connection.
TyrusWebSocket(ProtocolHandler, TyrusEndpointWrapper) - Constructor for class org.glassfish.tyrus.core.TyrusWebSocket
Create new instance, set ProtocolHandler and register TyrusEndpointWrapper.
TyrusWebSocketEngine - Class in org.glassfish.tyrus.core
WebSocketEngine implementation, which handles server-side handshake, validation and data processing.
TyrusWebSocketEngine(WebSocketContainer) - Constructor for class org.glassfish.tyrus.core.TyrusWebSocketEngine
Create WebSocketEngine instance based on passed WebSocketContainer.
TyrusWebSocketEngine(WebSocketContainer, Integer, ClusterContext) - Constructor for class org.glassfish.tyrus.core.TyrusWebSocketEngine
Create WebSocketEngine instance based on passed WebSocketContainer and with configured maximal incoming buffer size.

U

UDecoder - Class in org.glassfish.grizzly.http.util
All URL decoding happens here.
UDecoder() - Constructor for class org.glassfish.grizzly.http.util.UDecoder
 
UDecoder(boolean) - Constructor for class org.glassfish.grizzly.http.util.UDecoder
 
UDPNIOAsyncQueueReader - Class in org.glassfish.grizzly.nio.transport
The UDP transport AsyncQueueReader implementation, based on the Java NIO
UDPNIOAsyncQueueReader(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueReader
 
UDPNIOAsyncQueueWriter - Class in org.glassfish.grizzly.nio.transport
The UDP transport AsyncQueueWriter implementation, based on the Java NIO
UDPNIOAsyncQueueWriter(NIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueWriter
 
UDPNIOBindingHandler - Class in org.glassfish.grizzly.nio.transport
This class may be used to apply a custom Processor and/or ProcessorSelector atomically within a bind operation - not something that can normally be done using the UDPNIOTransport alone.
UDPNIOBindingHandler(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
UDPNIOBindingHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOBindingHandler.Builder() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler.Builder
 
UDPNIOConnection - Class in org.glassfish.grizzly.nio.transport
Connection implementation for the UDPNIOTransport
UDPNIOConnection(UDPNIOTransport, DatagramChannel) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnection
 
UDPNIOConnectorHandler - Class in org.glassfish.grizzly.nio.transport
UDP NIO transport client side ConnectorHandler implementation
UDPNIOConnectorHandler(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
UDPNIOConnectorHandler.Builder - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOConnectorHandler.Builder() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler.Builder
 
UDPNIOServerConnection - Class in org.glassfish.grizzly.nio.transport
Server Connection implementation for the UDPNIOTransport
UDPNIOServerConnection(UDPNIOTransport, DatagramChannel) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
UDPNIOTemporarySelectorReader - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTemporarySelectorReader(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorReader
 
UDPNIOTemporarySelectorWriter - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTemporarySelectorWriter(UDPNIOTransport) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorWriter
 
UDPNIOTransport - Class in org.glassfish.grizzly.nio.transport
UDP NIO transport implementation
UDPNIOTransport() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
UDPNIOTransport(String) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
UDPNIOTransport.RegisterChannelCompletionHandler - Class in org.glassfish.grizzly.nio.transport
 
UDPNIOTransport.RegisterChannelCompletionHandler() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport.RegisterChannelCompletionHandler
 
UDPNIOTransport.TransportConnectorHandler - Class in org.glassfish.grizzly.nio.transport
Transport default UDPNIOConnectorHandler.
UDPNIOTransport.TransportConnectorHandler() - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransport.TransportConnectorHandler
 
UDPNIOTransportBuilder - Class in org.glassfish.grizzly.nio.transport
NIOTransportBuilder implementation for UDP.
UDPNIOTransportBuilder(Class<? extends UDPNIOTransport>) - Constructor for class org.glassfish.grizzly.nio.transport.UDPNIOTransportBuilder
 
UDPNIOTransportFilter - Class in org.glassfish.grizzly.nio.transport
The UDPNIOTransport's transport Filter implementation
UEncoder - Class in org.glassfish.grizzly.http.util
Efficient implementation for encoders.
UEncoder() - Constructor for class org.glassfish.grizzly.http.util.UEncoder
 
UNAUTHORIZED_401 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOBindingHandler
 
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
Unbinds bound Transport connection.
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOBindingHandler
 
unbind(CompletionHandler<Closeable>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOServerConnection
 
unbind(Connection) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
Unbinds bound Transport connection.
unbind(Connection) - Method in interface org.glassfish.grizzly.SocketBinder
Unbinds bound Transport connection.
unbindAll() - Method in class org.glassfish.grizzly.AbstractBindingHandler
This operation is not supported by implementations of AbstractBindingHandler.
unbindAll() - Method in class org.glassfish.grizzly.nio.NIOTransport
 
unbindAll() - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
unbindAll() - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
unbindAll() - Method in interface org.glassfish.grizzly.SocketBinder
Unbinds all bound Transport connections.
unblock(InetAddress, NetworkInterface, InetAddress) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnection
Unblocks multicast datagrams from the given source address.
uncaughtException(Thread, Throwable) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
underlying() - Method in interface org.glassfish.grizzly.Buffer
Return the underlying buffer
underlying() - Method in class org.glassfish.grizzly.memory.BuffersBuffer
 
underlying() - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
underlying() - Method in class org.glassfish.grizzly.memory.CompositeBuffer
 
underlying() - Method in class org.glassfish.grizzly.memory.HeapBuffer
 
underlyingInput - Variable in class org.glassfish.grizzly.streams.TransformerInput
 
underlyingOutput - Variable in class org.glassfish.grizzly.streams.TransformerOutput
 
unescape(String) - Method in class org.glassfish.grizzly.http.Cookie
 
unescape(String) - Method in class org.glassfish.grizzly.http.server.Request
 
unescapeDoubleQuotes(DataChunk) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Unescapes any double quotes in the given cookie value.
unescapeDoubleQuotes(ByteChunk) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Unescapes any double quotes in the given cookie value.
unescapeDoubleQuotes(BufferChunk) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Unescapes any double quotes in the given cookie value.
unescapeDoubleQuotes(CharChunk) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Unescapes any double quotes in the given cookie value.
unescapeDoubleQuotes(Buffer, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Un-escapes any double quotes in the given cookie value.
unescapeDoubleQuotes(String, int, int) - Static method in class org.glassfish.grizzly.http.util.CookieParserUtils
Unescapes any double quotes in the given cookie value.
UNEXPECTED_END_FRAGMENT() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
End fragment sent, but wasn''t processing any previous fragments.
UNEXPECTED_ERROR_CONNECTION_CLOSE() - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Unexpected error, closing connection.
UNEXPECTED_STATE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Unexpected state: {0}.
unframe(ByteBuffer) - Method in class org.glassfish.tyrus.core.ProtocolHandler
TODO!
UNHANDLED_TEXT_MESSAGE(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Unhandled text message.
UNLIMITED_SIZE - Static variable in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Constant set via AsyncQueueWriter.setMaxPendingBytesPerConnection(int) means the async write queue size is unlimited.
UNLIMITED_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
UNLIMITED_TRANSACTION_TIMEOUT - Static variable in interface org.glassfish.grizzly.threadpool.WorkerThread
 
unparsedHostC - Variable in class org.glassfish.grizzly.http.HttpRequestPacket
 
unregister(TyrusEndpointWrapper) - Method in class org.glassfish.tyrus.core.TyrusWebSocketEngine
Un-registers the specified TyrusEndpointWrapper with the WebSocketEngine.
UnsafeFutureImpl<R> - Class in org.glassfish.grizzly.impl
Simple thread-unsafe Future implementation.
UNSET - Static variable in class org.glassfish.grizzly.http.Cookie
 
UNSET_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.DelayedExecutor
 
UNSET_TIMEOUT - Static variable in class org.glassfish.grizzly.utils.SilentConnectionFilter
 
UNSUPPORTED_MEDIA_TYPE_415 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
unwrapAll(FilterChainContext, SSLConnectionContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
update(byte[], int, int) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
update(byte[]) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
updateByte(int) - Method in class org.glassfish.grizzly.compression.lzma.impl.CRC
 
updated(E) - Method in interface org.glassfish.grizzly.CompletionHandler
The callback method may be called, when there is some progress in operation execution, but it is still not completed
updated(E) - Method in class org.glassfish.grizzly.EmptyCompletionHandler
The callback method may be called, when there is some progress in operation execution, but it is still not completed
updated(Object) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter.DisposeBufferCompletionHandler
 
updated(B) - Method in class org.glassfish.grizzly.utils.CompletionHandlerAdapter
 
updated(E) - Method in class org.glassfish.tyrus.spi.CompletionHandler
The callback method may be called, when there is some progress in operation execution, but it is still not completed.
updatePaths(Request, MappingData) - Static method in class org.glassfish.grizzly.http.server.HttpHandler
Utility method to update Request path values.
upgrade - Variable in class org.glassfish.grizzly.http.HttpHeader.Builder
 
upgrade(String) - Method in class org.glassfish.grizzly.http.HttpHeader.Builder
Set the HTTP upgrade type.
upgrade - Variable in class org.glassfish.grizzly.http.HttpHeader
 
upgrade(UpgradeRequest) - Method in class org.glassfish.tyrus.core.TyrusEndpointWrapper
Server side check for protocol specific information to determine whether the request can be upgraded.
upgrade(UpgradeRequest, UpgradeResponse) - Method in class org.glassfish.tyrus.core.TyrusWebSocketEngine
 
UPGRADE - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
upgrade(UpgradeRequest, UpgradeResponse) - Method in interface org.glassfish.tyrus.spi.WebSocketEngine
A transport calls this method to upgrade a HTTP request.
UpgradeRequest - Class in org.glassfish.tyrus.spi
Abstraction for a HTTP upgrade request.
UpgradeRequest() - Constructor for class org.glassfish.tyrus.spi.UpgradeRequest
 
UpgradeResponse - Class in org.glassfish.tyrus.spi
Abstraction for a HTTP upgrade response.
UpgradeResponse() - Constructor for class org.glassfish.tyrus.spi.UpgradeResponse
 
uri - Variable in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
 
uri(String) - Method in class org.glassfish.grizzly.http.HttpRequestPacket.Builder
Set the request URI.
uri - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheKey
 
URI_COMPONENT_ENCODED_OCTET_INVALID_DIGIT(Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Malformed percent-encoded octet at index {0}, invalid hexadecimal digit ''{1}''.
URI_COMPONENT_ENCODED_OCTET_MALFORMED(Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
Malformed percent-encoded octet at index {0}.
URI_COMPONENT_INVALID_CHARACTER(Object, Object, Object, Object) - Static method in class org.glassfish.tyrus.core.l10n.LocalizationMessages
The string "{0}" for the URI component {1} contains an invalid character, ''{2}'', at index {3}.
UriComponent - Class in org.glassfish.tyrus.core.uri.internal
Utility class for validating, encoding and decoding components of a URI.
UriComponent.Type - Enum in org.glassfish.tyrus.core.uri.internal
The URI component type.
UriTemplate - Class in org.glassfish.tyrus.core.uri.internal
A URI template.
UriTemplate(String) - Constructor for class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a new URI template.
UriTemplate(UriTemplateParser) - Constructor for class org.glassfish.tyrus.core.uri.internal.UriTemplate
Construct a new URI template.
UriTemplateParser - Class in org.glassfish.tyrus.core.uri.internal
A URI template parser that parses JAX-RS specific URI templates.
UriTemplateParser(String) - Constructor for class org.glassfish.tyrus.core.uri.internal.UriTemplateParser
Parse a template.
URLDecoder - Class in org.glassfish.grizzly.http.util
 
URLDecoder() - Constructor for class org.glassfish.grizzly.http.util.URLDecoder
 
urlEncode(Writer, String) - Method in class org.glassfish.grizzly.http.util.UEncoder
URL Encode string, using a specified encoding.
urlEncode(Writer, String, boolean) - Method in class org.glassfish.grizzly.http.util.UEncoder
URL Encode string, using a specified encoding.
urlEncode(Writer, byte[], int, int) - Method in class org.glassfish.grizzly.http.util.UEncoder
 
urlEncode(Writer, byte[], int, int, boolean) - Method in class org.glassfish.grizzly.http.util.UEncoder
 
urlEncoder - Variable in class org.glassfish.grizzly.http.server.Response
URL encoder.
USE_PROXY_305 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
USE_SEND_FILE - Static variable in class org.glassfish.grizzly.http.server.ServerFilterConfiguration
 
userPrincipal - Variable in class org.glassfish.grizzly.http.server.Request
User principal.
userPrincipal(Principal) - Method in class org.glassfish.tyrus.core.RequestContext.Builder
usingInputStream - Variable in class org.glassfish.grizzly.http.server.Request
Using stream flag.
usingLazyCookieState - Variable in class org.glassfish.grizzly.http.Cookie
 
usingOutputStream - Variable in class org.glassfish.grizzly.http.server.Response
Using output stream flag.
usingReader - Variable in class org.glassfish.grizzly.http.server.Request
Using writer flag.
usingWriter - Variable in class org.glassfish.grizzly.http.server.Response
Using writer flag.
UTF8_CHARSET - Static variable in class org.glassfish.grizzly.utils.Charsets
 
UTF8Decoder - Class in org.glassfish.grizzly.http.util
Moved from ByteChunk - code to convert from UTF8 bytes to chars.
UTF8Decoder() - Constructor for class org.glassfish.grizzly.http.util.UTF8Decoder
 
Utf8DecodingException - Exception in org.glassfish.tyrus.core
TODO
Utf8DecodingException() - Constructor for exception org.glassfish.tyrus.core.Utf8DecodingException
TODO
Utf8Utils - Class in org.glassfish.tyrus.core
 
Utf8Utils() - Constructor for class org.glassfish.tyrus.core.Utf8Utils
 
Utils - Class in org.glassfish.tyrus.core
Utility methods shared among Tyrus modules.
Utils() - Constructor for class org.glassfish.tyrus.core.Utils
 
Utils.Stringifier<T> - Class in org.glassfish.tyrus.core
Define to String conversion for various types.
Utils.Stringifier() - Constructor for class org.glassfish.tyrus.core.Utils.Stringifier
 

V

valid(String, UriComponent.Type) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Validates the legal characters of a percent-encoded string that represents a URI component type.
valid(String, UriComponent.Type, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Validates the legal characters of a percent-encoded string that represents a URI component type.
validate(String, UriComponent.Type) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Validates the legal characters of a percent-encoded string that represents a URI component type.
validate(String, UriComponent.Type, boolean) - Static method in class org.glassfish.tyrus.core.uri.internal.UriComponent
Validates the legal characters of a percent-encoded string that represents a URI component type.
validate(UpgradeRequest) - Method in enum org.glassfish.tyrus.core.Version
 
validateConfiguration() - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Validates SSLContextConfigurator configuration.
validateConfiguration(boolean) - Method in class org.glassfish.grizzly.ssl.SSLContextConfigurator
Validates SSLContextConfigurator configuration.
validateNewPoolSize(int, int) - Method in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
validateServerResponse(UpgradeResponse) - Method in class org.glassfish.tyrus.core.Handshake
 
value - Variable in class org.glassfish.grizzly.http.Cookie
 
value - Variable in class org.glassfish.grizzly.http.util.StringCache.ByteEntry
 
value - Variable in class org.glassfish.grizzly.http.util.StringCache.CharEntry
 
valueOf(String) - Static method in enum javax.websocket.CloseReason.CloseCodes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.CloseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.compression.lzma.impl.Decoder.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.compression.zip.GZipDecoder.DecodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.Connection.CloseType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.DefaultFilterChain.FILTER_STATE_TYPE
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.CompressionConfig.CompressionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.Method.PayloadExpectation
Returns the enum constant of this type with the specified name.
valueOf(DataChunk) - Static method in class org.glassfish.grizzly.http.Method
 
valueOf(String) - Static method in class org.glassfish.grizzly.http.Method
 
valueOf(String) - Static method in enum org.glassfish.grizzly.http.Protocol
Returns the enum constant of this type with the specified name.
valueOf(byte[], int, int) - Static method in enum org.glassfish.grizzly.http.Protocol
 
valueOf(Buffer, int, int) - Static method in enum org.glassfish.grizzly.http.Protocol
 
valueOf(DataChunk) - Static method in enum org.glassfish.grizzly.http.Protocol
 
valueOf(String) - Static method in enum org.glassfish.grizzly.http.server.CompressionLevel
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.server.filecache.FileCache.CacheResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.server.filecache.FileCache.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.util.DataChunk.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.http.util.Header
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.IOEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.memory.CompositeBuffer.DisposeOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.glassfish.grizzly.PortRange
Parse a port range.
valueOf(String) - Static method in enum org.glassfish.grizzly.ProcessorResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.TransformationResult.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.Transport.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.grizzly.utils.ExceptionHandler.Severity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.core.CloseReasons
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.core.cluster.ClusterSession.DistributedMapKey
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.core.uri.internal.PathPattern.RightHandPath
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.core.uri.internal.UriComponent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.core.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.glassfish.tyrus.spi.WebSocketEngine.UpgradeStatus
Returns the enum constant of this type with the specified name.
values() - Static method in enum javax.websocket.CloseReason.CloseCodes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.asyncqueue.AsyncQueue.AsyncResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.CloseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.compression.lzma.impl.Decoder.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.compression.zip.GZipDecoder.DecodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.Connection.CloseType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.DefaultFilterChain.FILTER_STATE_TYPE
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.filterchain.FilterChainContext.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.CompressionConfig.CompressionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.Method.PayloadExpectation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.server.CompressionLevel
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.server.filecache.FileCache.CacheResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.server.filecache.FileCache.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.util.DataChunk.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.http.util.Header
Returns an array containing the constants of this enum type, in the order they are declared.
values(String) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
values(Header) - Method in class org.glassfish.grizzly.http.util.MimeHeaders
 
values() - Static method in enum org.glassfish.grizzly.IOEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.memory.CompositeBuffer.DisposeOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.ProcessorResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.TransformationResult.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.Transport.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.grizzly.utils.ExceptionHandler.Severity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.tyrus.core.CloseReasons
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.tyrus.core.cluster.ClusterSession.DistributedMapKey
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.glassfish.tyrus.core.uri.internal.AbstractMultivaluedMap
 
values() - Static method in enum org.glassfish.tyrus.core.uri.internal.PathPattern.RightHandPath
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.tyrus.core.uri.internal.UriComponent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.tyrus.core.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.glassfish.tyrus.spi.WebSocketEngine.UpgradeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class org.glassfish.grizzly.http.Cookie
 
Version - Enum in org.glassfish.tyrus.core
TODO
visible - Variable in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
VOID_FILTER - Static variable in class org.glassfish.grizzly.http.server.Constants
Void filters (input and output).

W

waitNIOFuture(FutureImpl<Connection>, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOConnectorHandler
 
waitNIOFuture(FutureImpl<Connection>, CompletionHandler<Connection>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOConnectorHandler
 
wakeupSelector() - Method in class org.glassfish.grizzly.nio.SelectorRunner
 
wantClientAuth - Variable in class org.glassfish.grizzly.ssl.SSLEngineConfigurator
True when requesting authentication.
wantDecode(HttpHeader) - Method in class org.glassfish.grizzly.http.ChunkedTransferEncoding
Return true if this encoding should be used to parse the content of the passed HttpHeader, or false otherwise.
wantDecode(HttpHeader) - Method in interface org.glassfish.grizzly.http.ContentEncoding
Method should implement the logic, which decides if HTTP packet with the specific HttpHeader should be decoded using this ContentEncoding.
wantDecode(HttpHeader) - Method in class org.glassfish.grizzly.http.FixedLengthTransferEncoding
Return true if this encoding should be used to parse the content of the passed HttpHeader, or false otherwise.
wantDecode(HttpHeader) - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
wantDecode(HttpHeader) - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
wantDecode(HttpHeader) - Method in interface org.glassfish.grizzly.http.TransferEncoding
Return true if this encoding should be used to parse the content of the passed HttpHeader, or false otherwise.
wantEncode(HttpHeader) - Method in class org.glassfish.grizzly.http.ChunkedTransferEncoding
Return true if this encoding should be used to serialize the content of the passed HttpHeader, or false otherwise.
wantEncode(HttpHeader) - Method in interface org.glassfish.grizzly.http.ContentEncoding
Method should implement the logic, which decides if HTTP packet with the specific HttpHeader should be encoded using this ContentEncoding.
wantEncode(HttpHeader) - Method in class org.glassfish.grizzly.http.FixedLengthTransferEncoding
Return true if this encoding should be used to serialize the content of the passed HttpHeader, or false otherwise.
wantEncode(HttpHeader) - Method in class org.glassfish.grizzly.http.GZipContentEncoding
 
wantEncode(HttpHeader) - Method in class org.glassfish.grizzly.http.LZMAContentEncoding
 
wantEncode(HttpHeader) - Method in interface org.glassfish.grizzly.http.TransferEncoding
Return true if this encoding should be used to serialize the content of the passed HttpHeader, or false otherwise.
wantReset(int) - Method in interface org.glassfish.grizzly.memory.ThreadLocalPool
 
WARNING_GRIZZLY_BUFFERS_OVERFLOW_EXCEPTION(Object, Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0012: BufferOverflow srcBuffer={0} srcOffset={1} length={2} dstBuffer={3}
WARNING_GRIZZLY_CONFIG_SSL_GENERAL_CONFIG_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0050: SSL support could not be configured!
WARNING_GRIZZLY_CONFIG_SSL_SECURE_PASSWORD_INITIALIZATION_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0051: Secure password provider could not be initialized: {0}.
WARNING_GRIZZLY_CONFIG_SSL_SSL_IMPLEMENTATION_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0052: Unable to load SSLImplementation: {0}.
WARNING_GRIZZLY_CONFIG_SSL_UNKNOWN_CIPHER_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0053: Unrecognized cipher [{0}].
WARNING_GRIZZLY_CONNECTION_GET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0018: Error getting read buffer size
WARNING_GRIZZLY_CONNECTION_GET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0019: Error getting write buffer size
WARNING_GRIZZLY_CONNECTION_SET_READBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0016: Error setting read buffer size
WARNING_GRIZZLY_CONNECTION_SET_WRITEBUFFER_SIZE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0017: Error setting write buffer size
WARNING_GRIZZLY_CONNECTION_UDPMULTICASTING_EXCEPTIONE() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0033: Can't initialize reflection methods for DatagramChannel multicasting
WARNING_GRIZZLY_FILTERCHAIN_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0013: Exception during FilterChain execution
WARNING_GRIZZLY_GRACEFULSHUTDOWN_EXCEEDED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0031: Shutdown grace period exceeded.
WARNING_GRIZZLY_GRACEFULSHUTDOWN_INTERRUPTED() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0032: Primary shutdown thread interrupted.
WARNING_GRIZZLY_GRACEFULSHUTDOWN_MSG(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0030: Shutting down transport {0} in {1} {2}.
WARNING_GRIZZLY_HTTP_SERVER_FILECACHE_GENERAL_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0208: File cache exception
WARNING_GRIZZLY_HTTP_SERVER_FILTER_HTTPHANDLER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0202: Exception during HttpHandler invocation
WARNING_GRIZZLY_HTTP_SERVER_FILTER_UNEXPECTED() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0203: Unexpected error
WARNING_GRIZZLY_HTTP_SERVER_HTTPHANDLER_SERVICE_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0200: Service exception
WARNING_GRIZZLY_HTTP_SERVER_HTTPHANDLERCHAIN_ERRORPAGE() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0201: Unable to set error page
WARNING_GRIZZLY_HTTP_SERVER_REQUEST_AFTERSERVICE_NOTIFICATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0204: Unexpected error during afterService notification
WARNING_GRIZZLY_HTTP_SERVER_REQUEST_BODY_SKIP() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0206: Exception occurred during body skip
WARNING_GRIZZLY_HTTP_SERVER_REQUEST_POST_TOO_LARGE() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0205: Post too large
WARNING_GRIZZLY_HTTP_SERVER_REQUESTUTILS_SENDFILE_FAILED() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0211: SendFile can't be performed, because response headers are committed
WARNING_GRIZZLY_HTTP_SERVER_RESPONSE_FINISH_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0207: Error during the Response finish phase
WARNING_GRIZZLY_HTTP_SERVER_SERVEROUTPUTBUFFER_FILE_TRANSFER_CANCELLED(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0209: Transfer of file {0} was cancelled.
WARNING_GRIZZLY_HTTP_SERVER_SERVEROUTPUTBUFFER_FILE_TRANSFER_FAILED(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0210: "Failed to transfer file {0}.
WARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_ADD_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0302: Exception invoking attributeAdded() or attributeReplaced() on {0}: {1}.
WARNING_GRIZZLY_HTTP_SERVLET_ATTRIBUTE_LISTENER_REMOVE_ERROR(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0303: Exception invoking attributeRemoved() on {0}: {1}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_DESTROYED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0301: Exception invoking {0}() on {1}: {2}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTAINER_OBJECT_INITIALIZED_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0300: Exception invoking {0}() on {1}: {2}.
WARNING_GRIZZLY_HTTP_SERVLET_CONTEXT_LISTENER_LOAD_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0306: Unable to load listener: {0}.
WARNING_GRIZZLY_HTTP_SERVLET_INPUTSTREAM_ISREADY_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0308: ReadListener has not been set.
WARNING_GRIZZLY_HTTP_SERVLET_INPUTSTREAM_SETREADLISTENER_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
Cannot set ReaderListener for non-async or non-upgrade request
WARNING_GRIZZLY_HTTP_SERVLET_NON_BLOCKING_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0307: Can't block in non-blocking mode.
WARNING_GRIZZLY_HTTP_SERVLET_OUTPUTSTREAM_ISREADY_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0309: WriteListener has not been set.
WARNING_GRIZZLY_HTTP_SERVLET_OUTPUTSTREAM_SETWRITELISTENER_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
Cannot set WriteListener for non-async or non-upgrade request
WARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_BOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0305: Exception invoking valueBound() on HttpSessionBindingListener {0}.
WARNING_GRIZZLY_HTTP_SERVLET_SESSION_LISTENER_UNBOUND_ERROR(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0304: Exception invoking valueUnbound() on HttpSessionBindingListener {0}.
WARNING_GRIZZLY_HTTP_SEVERE_GRIZZLY_HTTP_PARAMETERS_MAX_COUNT_FAIL(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0173: More than the maximum number of request parameters (GET plus POST) for a single request ([{0}]) were detected.
WARNING_GRIZZLY_IOSTRATEGY_UNCAUGHT_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0010: Uncaught exception:
WARNING_GRIZZLY_PROCESSOR_ERROR(Object, Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0029: Error during Processor execution.
WARNING_GRIZZLY_SELECTOR_RUNNER_NOT_IN_STOPPED_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0014: SelectorRunner is not in the stopped state!
WARNING_GRIZZLY_SOCKET_KEEPALIVE_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0005: Can not set SO_KEEPALIVE to {0}
WARNING_GRIZZLY_SOCKET_LINGER_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0003: Can not set SO_LINGER to {0}
WARNING_GRIZZLY_SOCKET_REUSEADDRESS_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0006: Can not set SO_REUSEADDR to {0}
WARNING_GRIZZLY_SOCKET_TCPNODELAY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0004: Can not set TCP_NODELAY to {0}
WARNING_GRIZZLY_SOCKET_TIMEOUT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0007: Can not set SO_TIMEOUT to {0}
WARNING_GRIZZLY_STATE_HOLDER_CALLING_CONDITIONLISTENER_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0015: Error calling ConditionListener
WARNING_GRIZZLY_TCPSELECTOR_HANDLER_ACCEPTCHANNEL_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0008: Exception accepting channel
WARNING_GRIZZLY_TEMPORARY_SELECTOR_IO_CANCEL_KEY_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0025: Unexpected exception, when canceling the SelectionKey: {0}
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_CREATE_SELECTOR_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0026: SelectorFactory.
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_MISSES_EXCEPTION(Object, Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0027: SelectorFactory.
WARNING_GRIZZLY_TEMPORARY_SELECTOR_POOL_SELECTOR_FAILURE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0028: Temporary Selector failure.
WARNING_GRIZZLY_THREADPOOL_UNCAUGHT_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0011: Uncaught exception on thread {0}
WARNING_GRIZZLY_TRANSPORT_NOT_PAUSE_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0022: Transport is not in PAUSE state!
WARNING_GRIZZLY_TRANSPORT_NOT_START_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0021: Transport is not in START state!
WARNING_GRIZZLY_TRANSPORT_NOT_STOP_STATE_EXCEPTION() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0020: Transport is not in STOP state!
WARNING_GRIZZLY_TRANSPORT_START_SERVER_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0023: Exception occurred when starting server connection {0}
WARNING_GRIZZLY_TRANSPORT_UNBINDING_CONNECTION_EXCEPTION(Object) - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0024: Error unbinding connection {0}
WARNING_GRIZZLY_UTILS_STATE_HOLDER_CONDITION_LISTENER_INVOCATION_ERROR() - Static method in class org.glassfish.grizzly.localization.LogMessages
GRIZZLY0558: Error calling ConditionListener.
wasSuspended - Variable in class org.glassfish.grizzly.Context
true if this IOEvent processing was suspended during its processing, or false otherwise.
wasSuspended() - Method in class org.glassfish.grizzly.Context
 
WEB_SOCKET_PROTOCOL_HANDSHAKE_101 - Static variable in class org.glassfish.grizzly.http.util.HttpStatus
 
WEBSOCKET - Static variable in class org.glassfish.tyrus.spi.UpgradeRequest
 
WebSocketContainer - Interface in javax.websocket
A WebSocketContainer is an implementation provided object that provides applications a view on the container running it.
WebSocketEngine - Interface in org.glassfish.tyrus.spi
WebSocket engine is used for upgrading HTTP requests into websocket connections.
WebSocketEngine.UpgradeInfo - Interface in org.glassfish.tyrus.spi
Upgrade info that includes status for HTTP request upgrading and connection creation details.
WebSocketEngine.UpgradeStatus - Enum in org.glassfish.tyrus.spi
Upgrade Status for HTTP request upgrading
WebSocketException - Exception in org.glassfish.tyrus.core
WebSocketException can be thrown during runtime (after handshake).
WebSocketException(String) - Constructor for exception org.glassfish.tyrus.core.WebSocketException
Create new WebSocketException.
WELCOME_FILES_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which we record the set of welcome files (as an object of type String[]) for this application.
welcomeResources - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
wildcardWrappers - Variable in class org.glassfish.grizzly.http.server.util.Mapper.Context
 
willAllocateDirect(int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willAllocateDirect(int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willAllocateDirect(int) - Method in interface org.glassfish.grizzly.memory.MemoryManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willAllocateDirect(int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
Return true if next MemoryManager.allocate(int) or MemoryManager.allocateAtLeast(int) call, made in the current thread for the given memory size, going to return a Buffer based on direct ByteBuffer, or false otherwise.
willDecode(ByteBuffer) - Method in interface javax.websocket.Decoder.Binary
Answer whether the given bytes can be decoded into an object of type T.
willDecode(String) - Method in interface javax.websocket.Decoder.Text
Answer whether the given String can be decoded into an object of type T.
willDecode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.InputStreamDecoder
 
willDecode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.NoOpByteArrayCoder
 
willDecode(ByteBuffer) - Method in class org.glassfish.tyrus.core.coder.NoOpByteBufferCoder
 
willDecode(String) - Method in class org.glassfish.tyrus.core.coder.NoOpTextCoder
 
willDecode(String) - Method in class org.glassfish.tyrus.core.coder.PrimitiveDecoders
 
willDecode(String) - Method in class org.glassfish.tyrus.core.coder.ReaderDecoder
 
WORK_DIR_ATTR - Static variable in class org.glassfish.grizzly.http.server.util.Globals
The servlet context attribute under which we store a temporary working directory (as an object of type File) for use by servlets within this web application.
WORKER_THREAD_POOL_CONFIG - Static variable in class org.glassfish.tyrus.container.grizzly.client.GrizzlyClientSocket
Client-side property to set custom worker ThreadPoolConfig.
workerConfig - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
workerPoolConfig - Variable in class org.glassfish.grizzly.AbstractTransport
 
workers - Variable in class org.glassfish.grizzly.threadpool.AbstractThreadPool
 
WorkerThread - Interface in org.glassfish.grizzly.threadpool
Interface, which Grizzly thread pool threads should implement.
WorkerThreadIOStrategy - Class in org.glassfish.grizzly.strategies
IOStrategy, which executes Processors in worker thread.
workerThreadPool - Variable in class org.glassfish.grizzly.AbstractTransport
Worker thread pool
WorkerThreadPoolConfigProducer - Interface in org.glassfish.grizzly.strategies
Strategy implementations may implement this interface to signify they have certain thread pool configuration requirements that could be used when building the runtime.
workQueue - Variable in class org.glassfish.grizzly.threadpool.FixedThreadPool
 
wrap(MemoryManager, String) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the String.
wrap(MemoryManager, String, Charset) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the String with the specific Charset.
wrap(MemoryManager, byte[]) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the byte array.
wrap(MemoryManager, byte[], int, int) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(MemoryManager, ByteBuffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Static method in class org.glassfish.grizzly.memory.HeapBuffer
 
wrap(byte[], int, int) - Static method in class org.glassfish.grizzly.memory.HeapBuffer
 
wrap(byte[]) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in class org.glassfish.grizzly.memory.HeapMemoryManager
Returns Buffer, which wraps the ByteBuffer.
wrap(byte[]) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
wrap(byte[], int, int) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
wrap(String) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
wrap(String, Charset) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
wrap(ByteBuffer) - Method in class org.glassfish.grizzly.memory.PooledMemoryManager
 
wrap(byte[]) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the byte array.
wrap(byte[], int, int) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the part of byte array with specific offset and length.
wrap(String) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the String.
wrap(String, Charset) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the String with the specific Charset.
wrap(ByteBuffer) - Method in interface org.glassfish.grizzly.memory.WrapperAware
Returns Buffer, which wraps the ByteBuffer.
wrap(Frame, byte, ByteBuffer) - Static method in class org.glassfish.tyrus.core.frame.TyrusFrame
TyrusFrame factory method.
wrapAll(FilterChainContext, SSLConnectionContext) - Method in class org.glassfish.grizzly.ssl.SSLBaseFilter
 
wrapByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferManager.SmallByteBufferWrapper
 
wrapByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.memory.ByteBufferWrapper
 
wrapper - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
WrapperAware - Interface in org.glassfish.grizzly.memory
MemoryManagers, which implement this interface, are able to convert frequently used Java buffer types to Grizzly Buffer.
wrapperPath - Variable in class org.glassfish.grizzly.http.server.util.MappingData
 
WritableMessage - Interface in org.glassfish.grizzly.asyncqueue
Common interface for entities that may be written to a Channel.
write(Connection<L>, WritableMessage) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage.
write(Connection<L>, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage.
write(Connection<L>, L, WritableMessage) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage to the specific address.
write(Connection<L>, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in class org.glassfish.grizzly.AbstractWriter
Method writes the WritableMessage to the specific address.
write(Connection<L>, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>, PushBackHandler, MessageCloner<WritableMessage>) - Method in interface org.glassfish.grizzly.asyncqueue.AsyncQueueWriter
Deprecated.
push back logic is deprecated
write(Connection, Object, Object, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
write(Connection, Object, Object, CompletionHandler<WriteResult>, MessageCloner) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
 
write(Connection, Object, Object, CompletionHandler, PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.DefaultFilterChain
Deprecated.
write(Object) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, CompletionHandler<WriteResult>, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Deprecated.
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Deprecated.
write(Object, Object, CompletionHandler<WriteResult>, MessageCloner) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, MessageCloner) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Deprecated.
write(Object, Object, CompletionHandler<WriteResult>, MessageCloner, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
 
write(Object, Object, CompletionHandler<WriteResult>, PushBackHandler, MessageCloner, boolean) - Method in class org.glassfish.grizzly.filterchain.FilterChainContext
Deprecated.
write(Buffer) - Method in interface org.glassfish.grizzly.http.io.BinaryNIOOutputSink
Writes the contents of the specified Buffer.
write(char[], int, int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(char[]) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(String) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(String, int, int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(byte[]) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(byte[], int, int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, MessageCloner<WritableMessage>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Deprecated.
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler, MessageCloner<WritableMessage>) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
Deprecated.
write(M) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(M, CompletionHandler<WriteResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(M, CompletionHandler<WriteResult<M, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.NIOConnection
Deprecated.
write(SocketAddress, M, CompletionHandler<WriteResult<M, SocketAddress>>) - Method in class org.glassfish.grizzly.nio.NIOConnection
 
write(SocketAddress, M, CompletionHandler<WriteResult<M, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.NIOConnection
Deprecated.
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, MessageCloner<WritableMessage>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Method writes the WritableMessage to the specific address.
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Deprecated.
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Method writes the WritableMessage to the specific address.
write(Connection<SocketAddress>, SocketAddress, WritableMessage, CompletionHandler<WriteResult<WritableMessage, SocketAddress>>, PushBackHandler, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Method writes the WritableMessage to the specific address.
write(TCPNIOConnection, WritableMessage) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
write(TCPNIOConnection, WritableMessage, WriteResult) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTransport
 
write(UDPNIOConnection, SocketAddress, WritableMessage) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
write(UDPNIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTransport
 
write(Connection, Object, Object, CompletionHandler<WriteResult>) - Method in interface org.glassfish.grizzly.Processor
 
write(Connection, Object, Object, CompletionHandler<WriteResult>, MessageCloner) - Method in interface org.glassfish.grizzly.Processor
 
write(Connection, Object, Object, CompletionHandler<WriteResult>, PushBackHandler) - Method in interface org.glassfish.grizzly.Processor
Deprecated.
write(Connection, Object, Object, CompletionHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
write(Connection, Object, Object, CompletionHandler, MessageCloner) - Method in class org.glassfish.grizzly.StandaloneProcessor
 
write(Connection, Object, Object, CompletionHandler, PushBackHandler) - Method in class org.glassfish.grizzly.StandaloneProcessor
Deprecated.
write(byte) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
write(Buffer) - Method in class org.glassfish.grizzly.streams.BufferedOutput
 
write(byte) - Method in interface org.glassfish.grizzly.streams.Output
 
write(Buffer) - Method in interface org.glassfish.grizzly.streams.Output
 
write(byte) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
write(Buffer) - Method in class org.glassfish.grizzly.streams.StreamOutput
 
write(int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(byte[]) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(byte[], int, int) - Method in class org.glassfish.grizzly.utils.BufferOutputStream
 
write(M) - Method in interface org.glassfish.grizzly.Writeable
Method writes the buffer.
write(M, CompletionHandler<WriteResult<M, L>>) - Method in interface org.glassfish.grizzly.Writeable
Method writes the buffer.
write(M, CompletionHandler<WriteResult<M, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writeable
Deprecated.
push back logic is deprecated
write(L, M, CompletionHandler<WriteResult<M, L>>) - Method in interface org.glassfish.grizzly.Writeable
Method writes the buffer to the specific address.
write(L, M, CompletionHandler<WriteResult<M, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writeable
Deprecated.
push back logic is deprecated
write(Connection<L>, WritableMessage) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage.
write(Connection<L>, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage.
write(Connection<L>, L, WritableMessage) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write(Connection<L>, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write(Connection<L>, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>, PushBackHandler) - Method in interface org.glassfish.grizzly.Writer
Deprecated.
push back logic is deprecated
write(Connection<L>, L, WritableMessage, CompletionHandler<WriteResult<WritableMessage, L>>, MessageCloner<WritableMessage>) - Method in interface org.glassfish.grizzly.Writer
Method writes the WritableMessage to the specific address.
write(ByteBuffer, CompletionHandler<ByteBuffer>) - Method in class org.glassfish.tyrus.container.grizzly.client.GrizzlyWriter
 
write(ByteBuffer, CompletionHandler<ByteBuffer>) - Method in class org.glassfish.tyrus.spi.Writer
Tyrus runtime calls this method to handover the data for a connection to the transport.
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.AbstractNIOAsyncQueueWriter
 
write0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>, long, TimeUnit) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
Flush the buffer by looping until the Buffer is empty
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
write0(NIOConnection, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOAsyncQueueWriter
 
write0(NIOConnection, AsyncWriteQueueRecord) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOAsyncQueueWriter
 
Writeable<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to write data from a Buffer.
writeBoolean(boolean) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the boolean value to the StreamWriter.
writeBoolean(boolean) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the boolean value to the StreamWriter.
writeBooleanArray(boolean[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of boolean values to the StreamWriter.
writeBooleanArray(boolean[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of boolean values to the StreamWriter.
writeBuffer(Buffer) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Writes the contents of the specified Buffer to the client.
writeBuffer(Buffer) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the Buffer to the StreamWriter.
writeBuffer(Buffer) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the Buffer to the StreamWriter.
writeBufferSize - Variable in class org.glassfish.grizzly.AbstractTransport
Transport default buffer size for write operations
writeBufferSize - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
writeByte(int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
writeByte(byte) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the byte value to the StreamWriter.
writeByte(byte) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the byte value to the StreamWriter.
writeByteArray(byte[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of byte values to the StreamWriter.
writeByteArray(byte[], int, int) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the part of array of byte values to the StreamWriter, using specific offset and length values.
writeByteArray(byte[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of byte values to the StreamWriter.
writeByteArray(byte[], int, int) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the part of array of byte values to the StreamWriter, using specific offset and length values.
writeByteBuffer(ByteBuffer) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
Writes the contents of the specified ByteBuffer to the client.
writeChar(int) - Method in class org.glassfish.grizzly.http.io.OutputBuffer
 
writeChar(char) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the char value to the StreamWriter.
writeChar(char) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the char value to the StreamWriter.
writeCharArray(char[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of char values to the StreamWriter.
writeCharArray(char[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of char values to the StreamWriter.
writeCoderProperties(Buffer) - Method in class org.glassfish.grizzly.compression.lzma.impl.Encoder
 
writeCompositeBuffer(TCPNIOConnection, CompositeBuffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
writeDouble(double) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the double value to the StreamWriter.
writeDouble(double) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the double value to the StreamWriter.
writeDoubleArray(double[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of double values to the StreamWriter.
writeDoubleArray(double[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of double values to the StreamWriter.
writeFloat(float) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the float value to the StreamWriter.
writeFloat(float) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the float value to the StreamWriter.
writeFloatArray(float[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of float values to the StreamWriter.
writeFloatArray(float[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of float values to the StreamWriter.
WriteHandler - Interface in org.glassfish.grizzly.http.server.io
Deprecated.
please use WriteHandler
WriteHandler - Interface in org.glassfish.grizzly
Callback notification mechanism that signals the developer it's possible to write content.
writeHandlersQueue - Variable in class org.glassfish.grizzly.asyncqueue.TaskQueue
 
writeInt(int) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
writeInt(int) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the int value to the StreamWriter.
writeIntArray(int[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of int values to the StreamWriter.
writeIntArray(int[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of int values to the StreamWriter.
writeLong(long) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the long value to the StreamWriter.
writeLong(long) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the long value to the StreamWriter.
writeLongArray(long[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of long values to the StreamWriter.
writeLongArray(long[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of long values to the StreamWriter.
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.tmpselectors.TemporarySelectorWriter
 
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.TCPNIOTemporarySelectorWriter
 
writeNow0(NIOConnection, SocketAddress, WritableMessage, WriteResult<WritableMessage, SocketAddress>) - Method in class org.glassfish.grizzly.nio.transport.UDPNIOTemporarySelectorWriter
 
Writer<L> - Interface in org.glassfish.grizzly
Implementations of this interface are able to write data from a Buffer to Connection.
Writer - Class in org.glassfish.tyrus.spi
Writer class that is used by tyrus runtime to pass outbound websocket data for a connection to a transport.
Writer() - Constructor for class org.glassfish.tyrus.spi.Writer
 
Writer.Reentrant - Class in org.glassfish.grizzly
Write reentrants counter
Writer.Reentrant() - Constructor for class org.glassfish.grizzly.Writer.Reentrant
 
WriteResult<K,L> - Class in org.glassfish.grizzly
Result of write operation, returned by Writeable.
WriteResult() - Constructor for class org.glassfish.grizzly.WriteResult
 
writeShort(short) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the short value to the StreamWriter.
writeShort(short) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the short value to the StreamWriter.
writeShortArray(short[]) - Method in class org.glassfish.grizzly.streams.AbstractStreamWriter
Write the array of short values to the StreamWriter.
writeShortArray(short[]) - Method in interface org.glassfish.grizzly.streams.StreamWriter
Write the array of short values to the StreamWriter.
writeSimpleBuffer(TCPNIOConnection, Buffer) - Static method in class org.glassfish.grizzly.nio.transport.TCPNIOUtils
 
writeTimeout - Variable in class org.glassfish.grizzly.AbstractTransport
 
writeTimeout - Variable in class org.glassfish.grizzly.NIOTransportBuilder
 
writeTimeoutMillis - Variable in class org.glassfish.grizzly.nio.NIOConnection
 
writeTo(WritableByteChannel) - Method in class org.glassfish.grizzly.FileTransfer
Transfers the File backing this FileTransfer to the specified WritableByteChannel.
writeToFileChannel(FileChannel, Buffer) - Static method in class org.glassfish.grizzly.memory.Buffers
Writes data from the Buffer into the FileChannel.
writeTraceMessage(Request, Response) - Static method in class org.glassfish.grizzly.http.server.util.HtmlHelper
 

X

xPoweredBy - Variable in class org.glassfish.grizzly.http.server.filecache.FileCacheEntry
 

Z

Z - Static variable in class org.glassfish.grizzly.http.server.Constants
'Z'.
Z - Static variable in class org.glassfish.grizzly.http.util.Constants
'Z'.
ZERO - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
ZERO - Static variable in class org.glassfish.grizzly.streams.BufferedOutput
 
ZERO_READY_FUTURE - Static variable in class org.glassfish.grizzly.streams.AbstractStreamWriter
 
ZERO_READY_FUTURE - Static variable in class org.glassfish.grizzly.streams.BufferedOutput
 
zeroByteReadCount - Variable in class org.glassfish.grizzly.nio.NIOConnection
 

_

_200_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
_400_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
_404_BYTES - Static variable in class org.glassfish.grizzly.http.server.Constants
 
_blockSize - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_bufferBase - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_bufferOffset - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_pos - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
_streamPos - Variable in class org.glassfish.grizzly.compression.lzma.impl.lz.InWindow
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 

Copyright © 2012-2014, Oracle and/or its affiliates. All Rights Reserved. Use is subject to license terms.